Default package

Mouse Melon logoGet desktop application:
View/edit binary Protocol Buffers messages

service AccessControlService

AccessControl.proto:110

service AdminService

Admin.proto:225

service AggregateService

Aggregate.proto:54

* Refer to the AggregateImplementation class for an overview of the AggregateService method implementations and their functionality.

service AuthenticationService

Authentication.proto:75

RPC service

service ClientService

Client.proto:354

service MasterService

Master.proto:335

service MultiRowMutationService

MultiRowMutation.proto:38

service RegionServerStatusService

RegionServerStatus.proto:81

service RowProcessorService

RowProcessor.proto:39

service SecureBulkLoadService

SecureBulkLoad.proto:62

message Action

Client.proto:298

Either a Get or a Mutation

Used in: RegionAction

message AggregateRequest

Aggregate.proto:27

Used as request type in: AggregateService.GetAvg, AggregateService.GetMax, AggregateService.GetMedian, AggregateService.GetMin, AggregateService.GetRowNum, AggregateService.GetStd, AggregateService.GetSum

message AggregateResponse

Aggregate.proto:39

Used as response type in: AggregateService.GetAvg, AggregateService.GetMax, AggregateService.GetMedian, AggregateService.GetMin, AggregateService.GetRowNum, AggregateService.GetStd, AggregateService.GetSum

message AuthenticationKey

Authentication.proto:25

message BigDecimalMsg

HBase.proto:175

message BinaryComparator

Comparator.proto:38

message BinaryPrefixComparator

Comparator.proto:42

message BitComparator

Comparator.proto:46

enum BitComparator.BitwiseOp

Comparator.proto:50

Used in: BitComparator

message BulkLoadHFileRequest.FamilyPath

Client.proto:270

Used in: BulkLoadHFileRequest, SecureBulkLoadHFilesRequest

message ByteArrayComparable

Comparator.proto:34

Used in: BinaryComparator, BinaryPrefixComparator, BitComparator

message BytesBytesPair

HBase.proto:142

Used in: ColumnFamilySchema, FileInfoProto, FuzzyRowFilter, TableSchema

message Cell

Cell.proto:44

* Protocol buffer version of Cell.

Used in: Result

message CellBlockMeta

RPC.proto:92

Optional Cell block Message. Included in client RequestHeader

Used in: RequestHeader, ResponseHeader

enum CellType

Cell.proto:29

* The type of the key in a Cell

Used in: Cell, KeyValue

message ClusterId

ClusterId.proto:30

* Content of the '/hbase/hbaseid', cluster id, znode. Also cluster of the ${HBASE_ROOTDIR}/hbase.id file.

Used in: ClusterStatus

message ClusterStatus

ClusterStatus.proto:165

Used in: GetClusterStatusResponse

message ClusterUp

ZooKeeper.proto:55

* Content of the '/hbase/running', cluster state, znode.

message Column

Client.proto:35

* Container for a list of column qualifier names of a family.

Used in: Get, Scan

message ColumnCountGetFilter

Filter.proto:35

message ColumnFamilySchema

HBase.proto:51

* Column Family Schema Inspired by the rest ColumSchemaMessage

Used in: AddColumnRequest, ModifyColumnRequest, TableSchema

message ColumnPaginationFilter

Filter.proto:39

message ColumnPrefixFilter

Filter.proto:45

message ColumnRangeFilter

Filter.proto:49

message CompactionDescriptor

WAL.proto:80

* Special WAL entry to hold all related to a compaction. Written to WAL before completing compaction. There is sufficient info in the below message to complete later the * compaction should we fail the WAL write.

message Comparator

Comparator.proto:29

Used in: CompareFilter, Condition, SingleColumnValueFilter

message CompareFilter

Filter.proto:56

Used in: DependentColumnFilter, FamilyFilter, QualifierFilter, RowFilter, ValueFilter

enum CompareType

HBase.proto:107

Comparison operators

Used in: CompareFilter, Condition, SingleColumnValueFilter

message Condition

Client.proto:101

* Condition to check if the value of a given cell (row, family, qualifier) matches a value via a given comparator. Condition is used in check and mutate operations.

Used in: MutateRequest

message ConnectionHeader

RPC.proto:80

This is sent on connection setup after the connection preamble is sent.

message Coprocessor

HBase.proto:128

Used in: ClusterStatus, ServerLoad

message CoprocessorServiceCall

Client.proto:280

Used in: CoprocessorServiceRequest

message CoprocessorServiceRequest

Client.proto:287

Used as request type in: ClientService.ExecService, MasterService.ExecMasterService

message CoprocessorServiceResponse

Client.proto:292

Used as response type in: ClientService.ExecService, MasterService.ExecMasterService

message DelegationToken

SecureBulkLoad.proto:39

Used in: SecureBulkLoadHFilesRequest

message DependentColumnFilter

Filter.proto:61

message EmptyMsg

HBase.proto:167

(message has no fields)

message ExceptionResponse

RPC.proto:99

At the RPC layer, this message is used to carry the server side exception to the RPC client.

Used in: ResponseHeader

message FamilyFilter

Filter.proto:68

message FamilyScope

WAL.proto:65

Used in: WALKey

message FavoredNodes

HBase.proto:72

* Protocol buffer for favored nodes

message FileInfoProto

HFile.proto:27

Map of name/values

message FileTrailerProto

HFile.proto:32

HFile file trailer

message Filter

Filter.proto:30

Used in: FilterList, FilterWrapper, Get, Scan, SkipFilter, WhileMatchFilter

message FilterList

Filter.proto:72

enum FilterList.Operator

Filter.proto:76

Used in: FilterList

message FilterWrapper

Filter.proto:82

message FirstKeyOnlyFilter

Filter.proto:86

(message has no fields)

message FirstKeyValueMatchingQualifiersFilter

Filter.proto:89

message ForeignExceptionMessage

ErrorHandling.proto:54

* Exception sent across the wire when a remote task needs to notify other tasks that it failed and why

message FuzzyRowFilter

Filter.proto:93

message GenericExceptionMessage

ErrorHandling.proto:43

* Cause of a remote failure for a generic exception. Contains all the information for a generic exception as well as optional info about the error for generic info passing (which should be another protobuffed class).

Used in: ForeignExceptionMessage

message Get

Client.proto:46

* The protocol buffer version of Get. Unless existence_only is specified, return all the requested data for the row that matches exactly, or the one that immediately precedes it if closest_row_before is specified.

Used in: Action, GetRequest

enum GetRegionInfoResponse.CompactionState

Admin.proto:41

Used in: GetRegionInfoResponse

message GlobalPermission

AccessControl.proto:58

Used in: Permission

message HBaseVersionFileContent

FS.proto:29

* The ${HBASE_ROOTDIR}/hbase.version file content

Used in: ClusterStatus

message InclusiveStopFilter

Filter.proto:97

message KeyOnlyFilter

Filter.proto:101

message KeyValue

Cell.proto:57

* Protocol buffer version of KeyValue. It doesn't have those transient parameters

message LiveServerInfo

ClusterStatus.proto:160

Used in: ClusterStatus

message LoadBalancerState

LoadBalancer.proto:26

message LongMsg

HBase.proto:170

message Master

ZooKeeper.proto:45

* Content of the master znode.

message MetaRegionServer

ZooKeeper.proto:33

* Content of the meta-region-server znode.

message MultiRowMutationProcessorRequest

MultiRowMutation.proto:25

(message has no fields)

message MultiRowMutationProcessorResponse

MultiRowMutation.proto:28

(message has no fields)

message MultipleColumnPrefixFilter

Filter.proto:105

message MutationProto

Client.proto:117

* A specific mutation inside a mutate request. It can be an append, increment, put or delete based on the mutation type. It can be fully filled in or only metadata present because data is being carried elsewhere outside of pb.

Used in: Action, MutateRequest, MutateRowsRequest

message MutationProto.ColumnValue

Client.proto:158

Used in: MutationProto

message MutationProto.ColumnValue.QualifierValue

Client.proto:162

Used in: ColumnValue

enum MutationProto.DeleteType

Client.proto:151

Used in: ColumnValue.QualifierValue

enum MutationProto.Durability

Client.proto:136

Used in: MutationProto

enum MutationProto.MutationType

Client.proto:144

Used in: MutationProto

message NameBytesPair

HBase.proto:137

Used in: CoprocessorServiceResponse, Get, MutationProto, RegionActionResult, ResultOrException, Scan

message NameInt64Pair

HBase.proto:147

Used in: ScanMetrics

message NameStringPair

HBase.proto:132

Used in: ColumnFamilySchema, NamespaceDescriptor, RegionServerStartupResponse, TableSchema

message NamespaceDescriptor

HBase.proto:184

Used in: CreateNamespaceRequest, GetNamespaceDescriptorResponse, ListNamespaceDescriptorsResponse, ModifyNamespaceRequest

message NamespacePermission

AccessControl.proto:53

Used in: Permission

message NullComparator

Comparator.proto:57

(message has no fields)

message OpenRegionRequest.RegionOpenInfo

Admin.proto:72

Used in: OpenRegionRequest

enum OpenRegionResponse.RegionOpeningState

Admin.proto:82

Used in: OpenRegionResponse

message PageFilter

Filter.proto:109

message Permission

AccessControl.proto:27

Used in: CheckPermissionsRequest, UserPermission, UsersAndPermissions.UserPermissions

enum Permission.Action

AccessControl.proto:28

Used in: GlobalPermission, NamespacePermission, TablePermission

enum Permission.Type

AccessControl.proto:35

Used in: GetUserPermissionsRequest, Permission

message PrefixFilter

Filter.proto:113

message QualifierFilter

Filter.proto:117

message RPCTInfo

Tracing.proto:28

Used to pass through the information necessary to continue a trace after an RPC is made. All we need is the traceid (so we know the overarching trace this message is a part of), and the id of the current span when this message was sent, so we know what span caused the new span we will create when this message is received.

Used in: RequestHeader

message RandomRowFilter

Filter.proto:121

message Reference

FS.proto:36

* Reference file content used when we split an hfile under a region.

enum Reference.Range

FS.proto:38

Used in: Reference

message RegexStringComparator

Comparator.proto:60

message RegionAction

Client.proto:309

* Actions to run against a Region.

Used in: MultiRequest

message RegionActionResult

Client.proto:332

* The result of a RegionAction.

Used in: MultiResponse

message RegionInTransition

ClusterStatus.proto:57

Used in: ClusterStatus

message RegionInfo

HBase.proto:60

* Protocol buffer version of HRegionInfo.

Used in: GetOnlineRegionResponse, GetRegionInfoResponse, OpenRegionRequest.RegionOpenInfo, RegionState, UpdateFavoredNodesRequest.RegionUpdateInfo

message RegionLoad

ClusterStatus.proto:62

Used in: ServerLoad

message RegionServerInfo

HBase.proto:192

* Description of the region server info

message RegionSpecifier

HBase.proto:82

* Container protocol buffer to specify a region. You can specify region by region name, or the hash of the region name, which is known as encoded region name.

Used in: AssignRegionRequest, BulkLoadHFileRequest, CloseRegionRequest, CompactRegionRequest, CoprocessorServiceRequest, CoprocessorServiceResponse, DispatchMergingRegionsRequest, FlushRegionRequest, GetRegionInfoRequest, GetRequest, GetStoreFileRequest, MergeRegionsRequest, MoveRegionRequest, MutateRequest, OfflineRegionRequest, RegionAction, RegionInTransition, RegionLoad, ScanRequest, SplitRegionRequest, TableSnapshotRegionSplit, UnassignRegionRequest

enum RegionSpecifier.RegionSpecifierType

HBase.proto:86

Used in: RegionSpecifier

message RegionState

ClusterStatus.proto:30

Used in: RegionInTransition

enum RegionState.State

ClusterStatus.proto:34

Used in: RegionState

message RegionStoreSequenceIds

ZooKeeper.proto:167

* contains a sequence id of a region which should be the minimum of its store sequence ids and list sequence ids of the region's stores

message RegionTransition

ZooKeeper.proto:65

* What we write under unassigned up in zookeeper as a region moves through open/close, etc., regions. Details a region in transition.

message ReplicateWALEntryRequest

Admin.proto:191

* Replicates the given entries. The guarantee is that the given entries will be durable on the slave cluster if this method returns without any exception. hbase.replication has to be set to true for this to work.

Used as request type in: AdminService.Replay, AdminService.ReplicateWALEntry

message ReplicateWALEntryResponse

Admin.proto:195

Used as response type in: AdminService.Replay, AdminService.ReplicateWALEntry

(message has no fields)

message ReplicationHLogPosition

ZooKeeper.proto:132

* Used by replication. Holds the current position in an HLog file.

message ReplicationLock

ZooKeeper.proto:139

* Used by replication. Used to lock a region server during failover.

message ReplicationPeer

ZooKeeper.proto:112

* Used by replication. Holds a replication peer key.

message ReplicationState

ZooKeeper.proto:121

* Used by replication. Holds whether enabled or disabled

enum ReplicationState.State

ZooKeeper.proto:122

Used in: ReplicationState

message RequestHeader

RPC.proto:113

Header sent making a request.

message ResponseHeader

RPC.proto:127

message Result

Client.proto:66

Used in: GetResponse, MutateResponse, ResultOrException, ScanResponse

message ResultOrException

Client.proto:321

* Either a Result or an Exception NameBytesPair (keyed by exception name whose value is the exception stringified) or maybe empty if no result and no exception.

Used in: RegionActionResult

message RowFilter

Filter.proto:125

message Scan

Client.proto:202

* Instead of get from a table, you can scan it with optional filters. You can specify the row key range, time range, the columns/families to scan and so on. This scan is used the first time in a scan request. The response of the initial scan will return a scanner id, which should be used to fetch result batches later on before it is closed.

Used in: AggregateRequest, ScanRequest

message ScanMetrics

MapReduce.proto:28

enum ScopeType

WAL.proto:60

Used in: FamilyScope

message ServerInfo

Admin.proto:216

Used in: GetServerInfoResponse

message ServerLoad

ClusterStatus.proto:117

Used in: LiveServerInfo, RegionServerReportRequest

message ServerName

HBase.proto:120

* Protocol buffer version of ServerName

Used in: CloseRegionRequest, ClusterStatus, FavoredNodes, LiveServerInfo, Master, MetaRegionServer, MoveRegionRequest, OpenRegionRequest.RegionOpenInfo, RegionServerReportRequest, RegionTransition, ReportRSFatalErrorRequest, ServerInfo, SplitLogTask, TableLock, UpdateFavoredNodesRequest.RegionUpdateInfo

message SingleColumnValueExcludeFilter

Filter.proto:129

message SingleColumnValueFilter

Filter.proto:133

Used in: SingleColumnValueExcludeFilter

message SkipFilter

Filter.proto:142

message SnapshotDescription

HBase.proto:155

* Description of the snapshot to take

Used in: DeleteSnapshotRequest, GetCompletedSnapshotsResponse, IsRestoreSnapshotDoneRequest, IsSnapshotDoneRequest, IsSnapshotDoneResponse, RestoreSnapshotRequest, SnapshotRequest

enum SnapshotDescription.Type

HBase.proto:159

Used in: SnapshotDescription

message SplitLogTask

ZooKeeper.proto:80

* WAL SplitLog directory znodes have this for content. Used doing distributed WAL splitting. Holds current state and name of server that originated split.

enum SplitLogTask.State

ZooKeeper.proto:81

Used in: SplitLogTask

message StackTraceElementMessage

ErrorHandling.proto:30

* Protobuf version of a java.lang.StackTraceElement so we can serialize exceptions.

Used in: GenericExceptionMessage

message StoreSequenceId

ZooKeeper.proto:158

* sequence Id of a store

Used in: RegionStoreSequenceIds

message SubstringComparator

Comparator.proto:66

message Table

ZooKeeper.proto:95

* The znode that holds state of table.

enum Table.State

ZooKeeper.proto:97

Table's current state

Used in: Table

message TableLock

ZooKeeper.proto:146

* Metadata associated with a table lock in zookeeper

message TableName

HBase.proto:31

* Table Name

Used in: AddColumnRequest, DeleteColumnRequest, DeleteTableRequest, DisableTableRequest, EnableTableRequest, GetSchemaAlterStatusRequest, GetTableDescriptorsRequest, GetTableNamesResponse, GetUserPermissionsRequest, ListTableNamesByNamespaceResponse, ModifyColumnRequest, ModifyTableRequest, PrepareBulkLoadRequest, RegionInfo, TableLock, TablePermission, TableSchema

message TablePermission

AccessControl.proto:46

Used in: Permission

message TableSchema

HBase.proto:40

* Table Schema Inspired by the rest TableSchema

Used in: CreateTableRequest, GetTableDescriptorsResponse, ListTableDescriptorsByNamespaceResponse, ModifyTableRequest

message TableSnapshotRegionSplit

MapReduce.proto:32

message TimeRange

HBase.proto:101

* A range of time. Both from and to are Java time stamp in milliseconds. If you don't specify a time range, it means all time. By default, if not specified, from = 0, and to = Long.MAX_VALUE

Used in: Get, MutationProto, Scan

message TimestampsFilter

Filter.proto:146

message Token

Authentication.proto:47

Serialization of the org.apache.hadoop.security.token.Token class Note that this is a Hadoop class, so fields may change!

Used in: GetAuthenticationTokenResponse

message TokenIdentifier

Authentication.proto:32

enum TokenIdentifier.Kind

Authentication.proto:33

Used in: TokenIdentifier

message UUID

HBase.proto:179

Used in: WALKey

message UpdateFavoredNodesRequest.RegionUpdateInfo

Admin.proto:151

Used in: UpdateFavoredNodesRequest

message UserInformation

RPC.proto:74

User Information proto. Included in ConnectionHeader on connection setup

Used in: ConnectionHeader

message UserPermission

AccessControl.proto:62

Used in: GetUserPermissionsResponse, GrantRequest, RevokeRequest

message UsersAndPermissions

AccessControl.proto:70

* Content of the /hbase/acl/<table or namespace> znode.

message UsersAndPermissions.UserPermissions

AccessControl.proto:71

Used in: UsersAndPermissions

message ValueFilter

Filter.proto:150

message WALEntry

Admin.proto:176

Protocol buffer version of WAL for replication

Used in: ReplicateWALEntryRequest

message WALHeader

WAL.proto:26

message WALKey

WAL.proto:31

Protocol buffer version of HLogKey; see HLogKey comment, not really a key but WALEdit header for some KVs

Used in: WALEntry

message WALTrailer

WAL.proto:93

* A trailer that is appended to the end of a properly closed HLog WAL file. If missing, this is either a legacy or a corrupted WAL file.

(message has no fields)

message WhileMatchFilter

Filter.proto:154