Skip navigation links
Hortonworks Data Platform 3.0.0
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 

W

WAIT_ON_ENDPOINT_SECONDS - Static variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
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
 
WAIT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.rsgroup.TestRSGroupsBase
 
waitFailoverCleanup(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
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
 
waitForActiveAndReadyMaster(long) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
waitForAssignment(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
waitForAssignment(RegionInfo, long) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
waitForDataNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
waitForDataNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
waitForFinish() - Method in class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader
 
waitForFlushes() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Wait for all current flushes of the region to complete
waitForFlushes(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
waitForFlushesAndCompactions() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Wait for all current flushes and compactions of the region to complete
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
 
waitForProcedureToComplete(<any>, <any>, long) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitForProcedureToCompleteIOE(<any>, <any>, long) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitForRegionServers(MonitoredTask) - Method in class org.apache.hadoop.hbase.master.ServerManager
Wait for the region servers to report in.
waitForRegionServerToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
waitForReplication() - Method in class org.apache.hadoop.hbase.test.IntegrationTestReplication.VerifyReplicationLoop
 
waitForServerOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
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.
waitForZkNodeToStart(ServerName, long) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
waitForZkNodeToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
waiting() - Method in interface org.apache.hadoop.hbase.master.ServerListener
Started waiting on RegionServers to check-in.
waitingTimeForEvents - Variable in class org.apache.hadoop.hbase.executor.EventHandler
 
waitInitialized(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
waitMetaExclusiveLock(<any>) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Try to acquire the exclusive lock on meta.
waitMetaInitialized(Procedure) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
waitMetaInitialized(Procedure, RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
waitMetaLoaded(Procedure) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
waitMetaRegions(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitNamespaceExclusiveLock(Procedure, String) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Suspend the procedure if the specified namespace is already locked.
waitRegion(Procedure, RegionInfo) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Suspend the procedure if the specified region is already locked.
waitRegionInTransition(MasterProcedureEnv, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
 
waitRegions(Procedure, TableName, RegionInfo...) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Suspend the procedure if the specified set of regions are already locked.
waitServerCrashProcessingEnabled(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
waitServerExclusiveLock(Procedure, ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Try to acquire the exclusive lock on the specified server.
waitServerReportEvent(ServerName, Procedure) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
waitTableExclusiveLock(Procedure, TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Suspend the procedure if the specified table is already locked.
waitTableSharedLock(Procedure, TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Suspend the procedure if the specified table is already locked.
waitUntilShutDown() - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
wakeMetaExclusiveLock(<any>) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Wake the procedures waiting for meta.
wakeMetaLoadedEvent() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
wakeNamespaceExclusiveLock(Procedure, String) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Wake the procedures waiting for the specified namespace
wakeRegion(Procedure, RegionInfo) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Wake the procedures waiting for the specified region
wakeRegions(Procedure, TableName, RegionInfo...) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Wake the procedures waiting for the specified regions
wakeServerExclusiveLock(Procedure, ServerName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Wake the procedures waiting for the specified server
wakeServerReportEvent(RegionStates.ServerStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
wakeTableExclusiveLock(Procedure, TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Wake the procedures waiting for the specified table
wakeTableSharedLock(Procedure, TableName) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
Wake the procedures waiting for the specified table
WAL_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
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_DURABILITY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
 
WAL_ENTRY_FILTER_KEY - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.WALEntrySinkFilter
Name of configuration to set with name of implementing WALEntrySinkFilter class.
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
Set this to MultiTableOutputFormat.WAL_OFF to turn off write-ahead logging (WAL)
WALActionsListener - Interface in org.apache.hadoop.hbase.regionserver.wal
Get notification of WAL events.
walArchiveDir - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
dir path where old logs are kept.
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
 
WALCellFilter - Interface in org.apache.hadoop.hbase.replication
A filter for WAL entry cells before being sent over to replication.
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
walDir - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
WAL directory, where all WAL files would be placed.
walEntryFilter - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
WALEntryFilter - Interface in org.apache.hadoop.hbase.replication
A Filter for WAL entries before being sent over to replication.
WALEntrySinkFilter - Interface in org.apache.hadoop.hbase.replication.regionserver
Implementations are installed on a Replication Sink called from inside ReplicationSink#replicateEntries to filter replicated WALEntries based off WALEntry attributes.
walFactory - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
walFile2Props - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Map of WAL log file to properties.
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
 
WALFileLengthProvider - Interface in org.apache.hadoop.hbase.replication.regionserver
Used by replication to prevent replicating unacked log entries.
walFilePrefix - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Prefix of a WAL file, usually the region server name it is hosted on.
walFileSuffix - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Suffix included on generated wal file names
walFs - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
walGroupId - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
 
WALInputFormat - Class in org.apache.hadoop.hbase.mapreduce
Simple InputFormat for org.apache.hadoop.hbase.wal.WAL files.
WALInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
WALMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
 
WALMapperSearcher() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.WALSearcher.WALMapperSearcher
 
WALPlayer - Class in org.apache.hadoop.hbase.mapreduce
A tool to replay WAL files as a M/R job.
WALPlayer() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
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.
walRoller - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
walRollFinished() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
For testing only
walRollRequestFinished() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
For testing
WALSearcher(Configuration) - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.WALSearcher
 
WALStoreLeaseRecovery(MasterServices) - 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 (WAL).
warmupHRegion(RegionInfo, TableDescriptor, WAL, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
 
warmupRegion(RpcController, WarmupRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Wamrmup a region on this server.
WARN_RESPONSE_SIZE - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
WARN_RESPONSE_TIME - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
WARN_THRESHOLD_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
WARN_THRESHOLD_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
WarnOnlyAbortable() - Constructor for class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner.WarnOnlyAbortable
 
warnResponseSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
warnResponseTime - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
webAppContext - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
webServer - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
width - Variable in class org.apache.hadoop.hbase.test.IntegrationTestReplication
 
WINDOWS_PER_TIER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
 
withBloomType(BloomType) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
 
withComparator(CellComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
 
withFavoredNodes(InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
 
withFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
 
withFilePath(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
Use either this method or StoreFileWriter.Builder.withOutputDir(Path), but not both.
withMaxKeyCount(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
 
withOutputDir(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
Use either this method or StoreFileWriter.Builder.withFilePath(Path), but not both.
withParameters(String...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
 
withParameters(Class<?>...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
 
withShouldDropCacheBehind(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
 
workerThreads - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
workingDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
wrapMultiplier - Variable in class org.apache.hadoop.hbase.test.IntegrationTestReplication
 
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.Import.CellWritableComparable
 
write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable
 
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(Cell) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder
 
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.ProtobufStreamingOutput
 
write(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
 
write(ByteBuffer, int) - Method in class org.apache.hadoop.hbase.util.MapReduceExtendedCell
 
WRITE_OPERATION_LATENCY_DESC - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
WRITE_OPERATION_LATENCY_NAME - Static variable in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
 
WRITE_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
WRITE_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
WRITE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WRITE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
WRITE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
WRITE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableSource
 
writeBulkLoadMarkerAndSync(WAL, NavigableMap<byte[], Integer>, RegionInfo, WALProtos.BulkLoadDescriptor, MultiVersionConcurrencyControl) - 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.
writeCompactionMarker(WAL, NavigableMap<byte[], Integer>, RegionInfo, CompactionDescriptor, MultiVersionConcurrencyControl) - 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
 
writeFlushMarker(WAL, NavigableMap<byte[], Integer>, RegionInfo, FlushDescriptor, boolean, MultiVersionConcurrencyControl) - 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
writeMagicAndWALHeader(byte[], WALHeader) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
return the file length after written.
writeMagicAndWALHeader(byte[], WALHeader) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
writeMagicAndWALHeader(byte[], WALHeader) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
writer - Variable in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
writeRegionEventMarker(WAL, NavigableMap<byte[], Integer>, RegionInfo, RegionEventDescriptor, MultiVersionConcurrencyControl) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
Write a region open marker indicating that the region is opened.
writerFactory - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Factory that is used to produce single StoreFile.Writer-s
writers() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
 
writers() - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
 
writers() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
 
writerThreads - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
WriteSinkCoprocessor - Class in org.apache.hadoop.hbase.tool
This coprocessor 'shallows' all the writes.
WriteSinkCoprocessor() - Constructor for class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
 
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
 
writeWALTrailer() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
writeWALTrailerAndMagic(WALTrailer, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
writeWALTrailerAndMagic(WALTrailer, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
writeWALTrailerAndMagic(WALTrailer, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
WRITTEN_BYTES - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
WRITTEN_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
Skip navigation links
Hortonworks Data Platform 3.0.0