@InterfaceAudience.Private public final class RequestConverter extends Object
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequest buildGetRequest(byte[] regionName, Get get) throws IOException
regionName
- the name of the region to getget
- the client GetIOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest buildIncrementRequest(byte[] regionName, byte[] row, byte[] family, byte[] qualifier, long amount, Durability durability, long nonceGroup, long nonce)
regionName
- row
- family
- qualifier
- amount
- durability
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest buildMutateRequest(byte[] regionName, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Filter filter, TimeRange timeRange, Mutation mutation, long nonceGroup, long nonce) throws IOException
IOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest buildMultiRequest(byte[] regionName, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Filter filter, TimeRange timeRange, RowMutations rowMutations, long nonceGroup, long nonce) throws IOException
IOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest buildMultiRequest(byte[] regionName, RowMutations rowMutations, long nonceGroup, long nonce) throws IOException
IOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest buildMutateRequest(byte[] regionName, Put put) throws IOException
regionName
- put
- IOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest buildMutateRequest(byte[] regionName, Append append, long nonceGroup, long nonce) throws IOException
regionName
- append
- IOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest buildMutateRequest(byte[] regionName, Increment increment, long nonceGroup, long nonce) throws IOException
regionName
- increment
- IOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest buildMutateRequest(byte[] regionName, Delete delete) throws IOException
regionName
- delete
- IOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionAction.Builder getRegionActionBuilderWithRegion(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionAction.Builder regionActionBuilder, byte[] regionName)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest buildScanRequest(byte[] regionName, Scan scan, int numberOfRows, boolean closeScanner) throws IOException
regionName
- scan
- numberOfRows
- closeScanner
- IOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest buildScanRequest(long scannerId, int numberOfRows, boolean closeScanner, boolean trackMetrics)
scannerId
- numberOfRows
- closeScanner
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest buildScanRequest(long scannerId, int numberOfRows, boolean closeScanner, long nextCallSeq, boolean trackMetrics, boolean renew, int limitOfRows)
scannerId
- numberOfRows
- closeScanner
- nextCallSeq
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest buildBulkLoadHFileRequest(List<Pair<byte[],String>> familyPaths, byte[] regionName, boolean assignSeqNum, org.apache.hadoop.security.token.Token<?> userToken, String bulkToken)
familyPaths
- regionName
- assignSeqNum
- userToken
- bulkToken
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest buildBulkLoadHFileRequest(List<Pair<byte[],String>> familyPaths, byte[] regionName, boolean assignSeqNum, org.apache.hadoop.security.token.Token<?> userToken, String bulkToken, boolean copyFiles, List<String> clusterIds, boolean replicate)
familyPaths
- regionName
- assignSeqNum
- userToken
- bulkToken
- copyFiles
- public static void buildRegionActions(byte[] regionName, List<Action> actions, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest.Builder multiRequestBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionAction.Builder regionActionBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action.Builder actionBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.Builder mutationBuilder, long nonceGroup, Map<Integer,Integer> indexMap) throws IOException
regionName
- The region name of the actions.actions
- The actions that are grouped by the same region name.multiRequestBuilder
- The multiRequestBuilder to be populated with region actions.regionActionBuilder
- regionActionBuilder to be used to build region action.actionBuilder
- actionBuilder to be used to build action.mutationBuilder
- mutationBuilder to be used to build mutation.nonceGroup
- nonceGroup to be applied.indexMap
- Map of created RegionAction to the original index for a
RowMutations/CheckAndMutate within the original list of actionsIOException
public static void buildNoDataRegionActions(byte[] regionName, Iterable<Action> actions, List<CellScannable> cells, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest.Builder multiRequestBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionAction.Builder regionActionBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action.Builder actionBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.Builder mutationBuilder, long nonceGroup, Map<Integer,Integer> indexMap) throws IOException
data
param.
Propagates Actions original index.
The passed in multiRequestBuilder will be populated with region actions.
regionName
- The region name of the actions.actions
- The actions that are grouped by the same region name.cells
- Place to stuff references to actual data.multiRequestBuilder
- The multiRequestBuilder to be populated with region actions.regionActionBuilder
- regionActionBuilder to be used to build region action.actionBuilder
- actionBuilder to be used to build action.mutationBuilder
- mutationBuilder to be used to build mutation.nonceGroup
- nonceGroup to be applied.indexMap
- Map of created RegionAction to the original index for a
RowMutations/CheckAndMutate within the original list of actionsIOException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoRequest buildGetRegionInfoRequest(byte[] regionName)
regionName
- the name of the region to get infopublic static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoRequest buildGetRegionInfoRequest(byte[] regionName, boolean includeCompactionState)
regionName
- the name of the region to get infoincludeCompactionState
- indicate if the compaction state is requestedpublic static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoRequest buildGetRegionInfoRequest(byte[] regionName, boolean includeCompactionState, boolean includeBestSplitRow)
regionName
- the name of the region to get infoincludeCompactionState
- indicate if the compaction state is requestedincludeBestSplitRow
- indicate if the bestSplitRow is requestedpublic static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequest buildGetRegionLoadRequest(TableName tableName)
tableName
- the table for which regionLoad should be obtained from RSpublic static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionRequest buildGetOnlineRegionRequest()
public static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionRequest buildFlushRegionRequest(byte[] regionName)
regionName
- the name of the region to get infopublic static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionRequest buildFlushRegionRequest(byte[] regionName, byte[] columnFamily, boolean writeFlushWALMarker)
regionName
- the name of the region to get infocolumnFamily
- column family within a regionpublic static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest buildOpenRegionRequest(ServerName server, RegionInfo region, List<ServerName> favoredNodes)
server
- the serverName for the RPCregion
- the region to openfavoredNodes
- a list of favored nodespublic static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest buildUpdateFavoredNodesRequest(List<Pair<RegionInfo,List<ServerName>>> updateRegionInfos)
updateRegionInfos
- a list of favored node mappingspublic static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WarmupRegionRequest buildWarmupRegionRequest(RegionInfo regionInfo)
regionInfo
- Region we are warming uppublic static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionRequest buildCompactRegionRequest(byte[] regionName, boolean major, byte[] columnFamily)
regionName
- the name of the region to get infomajor
- indicator if it is a major compactioncolumnFamily
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterRequest buildRollWALWriterRequest()
public static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetServerInfoRequest buildGetServerInfoRequest()
public static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.StopServerRequest buildStopServerRequest(String reason)
reason
- the reason to stop the serverpublic static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier buildRegionSpecifier(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType type, byte[] value)
type
- the region specifier typevalue
- the region specifier byte array valuepublic static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnRequest buildAddColumnRequest(TableName tableName, ColumnFamilyDescriptor column, long nonceGroup, long nonce)
tableName
- column
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnRequest buildDeleteColumnRequest(TableName tableName, byte[] columnName, long nonceGroup, long nonce)
tableName
- columnName
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnRequest buildModifyColumnRequest(TableName tableName, ColumnFamilyDescriptor column, long nonceGroup, long nonce)
tableName
- column
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MoveRegionRequest buildMoveRegionRequest(byte[] encodedRegionName, ServerName destServerName)
encodedRegionName
- destServerName
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsRequest buildMergeTableRegionsRequest(byte[][] encodedNameOfdaughaterRegions, boolean forcible, long nonceGroup, long nonce) throws DeserializationException
DeserializationException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionRequest buildSplitTableRegionRequest(RegionInfo regionInfo, byte[] splitRow, long nonceGroup, long nonce) throws DeserializationException
DeserializationException
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignRegionRequest buildAssignRegionRequest(byte[] regionName)
regionName
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignRegionRequest buildUnassignRegionRequest(byte[] regionName)
regionName
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.OfflineRegionRequest buildOfflineRegionRequest(byte[] regionName)
regionName
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableRequest buildDeleteTableRequest(TableName tableName, long nonceGroup, long nonce)
tableName
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableRequest buildTruncateTableRequest(TableName tableName, boolean preserveSplits, long nonceGroup, long nonce)
tableName
- name of table to truncatepreserveSplits
- True if the splits should be preservedpublic static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableRequest buildEnableTableRequest(TableName tableName, long nonceGroup, long nonce)
tableName
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableRequest buildDisableTableRequest(TableName tableName, long nonceGroup, long nonce)
tableName
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableRequest buildCreateTableRequest(TableDescriptor tableDescriptor, byte[][] splitKeys, long nonceGroup, long nonce)
tableDescriptor
- splitKeys
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableRequest buildModifyTableRequest(TableName tableName, TableDescriptor tableDesc, long nonceGroup, long nonce)
tableName
- tableDesc
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest buildGetSchemaAlterStatusRequest(TableName tableName)
tableName
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest buildGetTableDescriptorsRequest(List<TableName> tableNames)
tableNames
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest buildGetTableDescriptorsRequest(Pattern pattern, boolean includeSysTables)
pattern
- The compiled regular expression to match againstincludeSysTables
- False to match only against userspace tablespublic static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableNamesRequest buildGetTableNamesRequest(Pattern pattern, boolean includeSysTables)
pattern
- The compiled regular expression to match againstincludeSysTables
- False to match only against userspace tablespublic static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateRequest buildGetTableStateRequest(TableName tableName)
tableName
- table to get request forpublic static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetTableStateInMetaRequest buildSetTableStateInMetaRequest(TableState state)
state
- table state to update in Metapublic static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetRegionStateInMetaRequest buildSetRegionStateInMetaRequest(Map<String,RegionState.State> nameOrEncodedName2State)
nameOrEncodedName2State
- list of regions states to update in Metapublic static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest buildGetTableDescriptorsRequest(TableName tableName)
tableName
- the table namepublic static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsMasterRunningRequest buildIsMasterRunningRequest()
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalanceRequest buildBalanceRequest(boolean force)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetBalancerRunningRequest buildSetBalancerRunningRequest(boolean on, boolean synchronous)
on
- synchronous
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsBalancerEnabledRequest buildIsBalancerEnabledRequest()
public static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheRequest buildClearRegionBlockCacheRequest(List<RegionInfo> hris)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetClusterStatusRequest buildGetClusterStatusRequest(EnumSet<ClusterMetrics.Option> options)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanRequest buildCatalogScanRequest()
MasterProtos.RunCatalogScanRequest
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest buildEnableCatalogJanitorRequest(boolean enable)
MasterProtos.EnableCatalogJanitorRequest
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest buildIsCatalogJanitorEnabledRequest()
MasterProtos.IsCatalogJanitorEnabledRequest
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCleanerChoreRequest buildRunCleanerChoreRequest()
MasterProtos.RunCleanerChoreRequest
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetCleanerChoreRunningRequest buildSetCleanerChoreRunningRequest(boolean on)
MasterProtos.SetCleanerChoreRunningRequest
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCleanerChoreEnabledRequest buildIsCleanerChoreEnabledRequest()
MasterProtos.IsCleanerChoreEnabledRequest
public static org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest buildGetLastFlushedSequenceIdRequest(byte[] regionName)
regionName
- RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
public static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo buildRegionOpenInfo(RegionInfo region, List<ServerName> favoredNodes, long openProcId)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.NormalizeRequest buildNormalizeRequest(NormalizeTableFilterParams ntfp)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest buildIsNormalizerEnabledRequest()
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetNormalizerRunningRequest buildSetNormalizerRunningRequest(boolean on)
on
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSplitOrMergeEnabledRequest buildIsSplitOrMergeEnabledRequest(MasterSwitchType switchType)
switchType
- see MasterSwitchType
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSplitOrMergeEnabledRequest buildSetSplitOrMergeEnabledRequest(boolean enabled, boolean synchronous, MasterSwitchType... switchTypes)
enabled
- switch is enabled or notsynchronous
- set switch sync?switchTypes
- see MasterSwitchType
, it is
a list.public static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerRequest buildAddReplicationPeerRequest(String peerId, ReplicationPeerConfig peerConfig, boolean enabled)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.RemoveReplicationPeerRequest buildRemoveReplicationPeerRequest(String peerId)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.EnableReplicationPeerRequest buildEnableReplicationPeerRequest(String peerId)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.DisableReplicationPeerRequest buildDisableReplicationPeerRequest(String peerId)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerConfigRequest buildGetReplicationPeerConfigRequest(String peerId)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigRequest buildUpdateReplicationPeerConfigRequest(String peerId, ReplicationPeerConfig peerConfig)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ListReplicationPeersRequest buildListReplicationPeersRequest(Pattern pattern)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateNamespaceRequest buildCreateNamespaceRequest(NamespaceDescriptor descriptor)
descriptor
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyNamespaceRequest buildModifyNamespaceRequest(NamespaceDescriptor descriptor)
descriptor
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteNamespaceRequest buildDeleteNamespaceRequest(String name)
name
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest buildGetNamespaceDescriptorRequest(String name)
name
- public static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearCompactionQueuesRequest buildClearCompactionQueuesRequest(Set<String> queues)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ClearDeadServersRequest buildClearDeadServersRequest(Collection<ServerName> deadServers)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesRequest buildGetSpaceQuotaRegionSizesRequest()
QuotaProtos.GetSpaceQuotaRegionSizesRequest
object.public static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaSnapshotsRequest buildGetSpaceQuotaSnapshotsRequest()
QuotaProtos.GetSpaceQuotaSnapshotsRequest
object.public static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesRequest buildGetQuotaStatesRequest()
QuotaProtos.GetQuotaStatesRequest
object.public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DecommissionRegionServersRequest buildDecommissionRegionServersRequest(List<ServerName> servers, boolean offload)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RecommissionRegionServerRequest buildRecommissionRegionServerRequest(ServerName server, List<byte[]> encodedRegionNames)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignsRequest toAssignRegionsRequest(List<String> encodedRegionNames, boolean override)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignsRequest toUnassignRegionsRequest(List<String> encodedRegionNames, boolean override)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ScheduleServerCrashProcedureRequest toScheduleServerCrashProcedureRequest(List<ServerName> serverNames)
public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSnapshotCleanupRequest buildSetSnapshotCleanupRequest(boolean enabled, boolean synchronous)
enabled
- Set to true
to enable,
false
to disable.synchronous
- If true
, it waits until current snapshot cleanup is completed,
if outstanding.public static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotCleanupEnabledRequest buildIsSnapshotCleanupEnabledRequest()
public static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogRequest buildSlowLogResponseRequest(Map<String,Object> filterParams, int limit, String logType)
filterParams
- map of filter paramslimit
- limit for no of records that server returnslogType
- type of the log recordsHBaseProtos.LogRequest
public static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearSlowLogResponseRequest buildClearSlowLogResponseRequest()
AdminProtos.ClearSlowLogResponseRequest
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.