@InterfaceAudience.Private public class SlowLogQueueService extends Object implements NamedQueueService
| Modifier and Type | Field and Description |
|---|---|
private boolean |
isOnlineLogProviderEnabled |
private boolean |
isSlowLogTableEnabled |
private static org.slf4j.Logger |
LOG |
private static String |
SLOW_LOG_RING_BUFFER_SIZE |
private SlowLogPersistentService |
slowLogPersistentService |
private Queue<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> |
slowLogQueue |
| Constructor and Description |
|---|
SlowLogQueueService(org.apache.hadoop.conf.Configuration conf) |
| Modifier and Type | Method and Description |
|---|---|
boolean |
clearNamedQueue()
Cleans up queues maintained by services.
|
void |
consumeEventFromDisruptor(NamedQueuePayload namedQueuePayload)
This implementation is specific to slowLog event.
|
NamedQueuePayload.NamedQueueEvent |
getEvent()
Retrieve event type for NamedQueueService implementation.
|
private List<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> |
getLargeLogPayloads(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.SlowLogResponseRequest request) |
private org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload.Type |
getLogType(RpcLogDetails rpcCallDetails) |
NamedQueueGetResponse |
getNamedQueueRecords(NamedQueueGetRequest request)
Retrieve in memory queue records from ringbuffer
|
private List<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> |
getSlowLogPayloads(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.SlowLogResponseRequest request) |
void |
persistAll()
Add all slowLog events to system table.
|
private static final org.slf4j.Logger LOG
private static final String SLOW_LOG_RING_BUFFER_SIZE
private final boolean isOnlineLogProviderEnabled
private final boolean isSlowLogTableEnabled
private final SlowLogPersistentService slowLogPersistentService
private final Queue<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> slowLogQueue
public SlowLogQueueService(org.apache.hadoop.conf.Configuration conf)
public NamedQueuePayload.NamedQueueEvent getEvent()
NamedQueueServicegetEvent in interface NamedQueueServiceNamedQueuePayload.NamedQueueEventpublic void consumeEventFromDisruptor(NamedQueuePayload namedQueuePayload)
consumeEventFromDisruptor in interface NamedQueueServicenamedQueuePayload - namedQueue payload from disruptor ring bufferpublic boolean clearNamedQueue()
NamedQueueServiceclearNamedQueue in interface NamedQueueServicepublic NamedQueueGetResponse getNamedQueueRecords(NamedQueueGetRequest request)
NamedQueueServicegetNamedQueueRecords in interface NamedQueueServicerequest - namedQueue request with event typeprivate org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload.Type getLogType(RpcLogDetails rpcCallDetails)
public void persistAll()
persistAll in interface NamedQueueServiceprivate List<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> getSlowLogPayloads(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.SlowLogResponseRequest request)
private List<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> getLargeLogPayloads(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.SlowLogResponseRequest request)
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.