public abstract static class HAServiceProtocolProtos.HAServiceProtocolService extends Object implements org.apache.hadoop.thirdparty.protobuf.Service
Protocol interface provides High availability related primitives to monitor and failover a service. For details see o.a.h.ha.HAServiceProtocol.Protobuf service
hadoop.common.HAServiceProtocolService
Modifier and Type | Class and Description |
---|---|
static interface |
HAServiceProtocolProtos.HAServiceProtocolService.BlockingInterface |
static interface |
HAServiceProtocolProtos.HAServiceProtocolService.Interface |
static class |
HAServiceProtocolProtos.HAServiceProtocolService.Stub |
Modifier | Constructor and Description |
---|---|
protected |
HAServiceProtocolService() |
Modifier and Type | Method and Description |
---|---|
void |
callMethod(org.apache.hadoop.thirdparty.protobuf.Descriptors.MethodDescriptor method,
org.apache.hadoop.thirdparty.protobuf.RpcController controller,
org.apache.hadoop.thirdparty.protobuf.Message request,
org.apache.hadoop.thirdparty.protobuf.RpcCallback<org.apache.hadoop.thirdparty.protobuf.Message> done) |
static org.apache.hadoop.thirdparty.protobuf.Descriptors.ServiceDescriptor |
getDescriptor() |
org.apache.hadoop.thirdparty.protobuf.Descriptors.ServiceDescriptor |
getDescriptorForType() |
org.apache.hadoop.thirdparty.protobuf.Message |
getRequestPrototype(org.apache.hadoop.thirdparty.protobuf.Descriptors.MethodDescriptor method) |
org.apache.hadoop.thirdparty.protobuf.Message |
getResponsePrototype(org.apache.hadoop.thirdparty.protobuf.Descriptors.MethodDescriptor method) |
abstract void |
getServiceStatus(org.apache.hadoop.thirdparty.protobuf.RpcController controller,
HAServiceProtocolProtos.GetServiceStatusRequestProto request,
org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.GetServiceStatusResponseProto> done)
Get the current status of the service.
|
abstract void |
monitorHealth(org.apache.hadoop.thirdparty.protobuf.RpcController controller,
HAServiceProtocolProtos.MonitorHealthRequestProto request,
org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.MonitorHealthResponseProto> done)
Monitor the health of a service.
|
static HAServiceProtocolProtos.HAServiceProtocolService.BlockingInterface |
newBlockingStub(org.apache.hadoop.thirdparty.protobuf.BlockingRpcChannel channel) |
static org.apache.hadoop.thirdparty.protobuf.BlockingService |
newReflectiveBlockingService(HAServiceProtocolProtos.HAServiceProtocolService.BlockingInterface impl) |
static org.apache.hadoop.thirdparty.protobuf.Service |
newReflectiveService(HAServiceProtocolProtos.HAServiceProtocolService.Interface impl) |
static HAServiceProtocolProtos.HAServiceProtocolService.Stub |
newStub(org.apache.hadoop.thirdparty.protobuf.RpcChannel channel) |
abstract void |
transitionToActive(org.apache.hadoop.thirdparty.protobuf.RpcController controller,
HAServiceProtocolProtos.TransitionToActiveRequestProto request,
org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.TransitionToActiveResponseProto> done)
Request service to tranisition to active state.
|
abstract void |
transitionToObserver(org.apache.hadoop.thirdparty.protobuf.RpcController controller,
HAServiceProtocolProtos.TransitionToObserverRequestProto request,
org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.TransitionToObserverResponseProto> done)
Request service to transition to observer state.
|
abstract void |
transitionToStandby(org.apache.hadoop.thirdparty.protobuf.RpcController controller,
HAServiceProtocolProtos.TransitionToStandbyRequestProto request,
org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.TransitionToStandbyResponseProto> done)
Request service to transition to standby state.
|
public static org.apache.hadoop.thirdparty.protobuf.Service newReflectiveService(HAServiceProtocolProtos.HAServiceProtocolService.Interface impl)
public static org.apache.hadoop.thirdparty.protobuf.BlockingService newReflectiveBlockingService(HAServiceProtocolProtos.HAServiceProtocolService.BlockingInterface impl)
public abstract void monitorHealth(org.apache.hadoop.thirdparty.protobuf.RpcController controller, HAServiceProtocolProtos.MonitorHealthRequestProto request, org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.MonitorHealthResponseProto> done)
Monitor the health of a service.
rpc monitorHealth(.hadoop.common.MonitorHealthRequestProto) returns (.hadoop.common.MonitorHealthResponseProto);
public abstract void transitionToActive(org.apache.hadoop.thirdparty.protobuf.RpcController controller, HAServiceProtocolProtos.TransitionToActiveRequestProto request, org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.TransitionToActiveResponseProto> done)
Request service to tranisition to active state.
rpc transitionToActive(.hadoop.common.TransitionToActiveRequestProto) returns (.hadoop.common.TransitionToActiveResponseProto);
public abstract void transitionToStandby(org.apache.hadoop.thirdparty.protobuf.RpcController controller, HAServiceProtocolProtos.TransitionToStandbyRequestProto request, org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.TransitionToStandbyResponseProto> done)
Request service to transition to standby state.
rpc transitionToStandby(.hadoop.common.TransitionToStandbyRequestProto) returns (.hadoop.common.TransitionToStandbyResponseProto);
public abstract void transitionToObserver(org.apache.hadoop.thirdparty.protobuf.RpcController controller, HAServiceProtocolProtos.TransitionToObserverRequestProto request, org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.TransitionToObserverResponseProto> done)
Request service to transition to observer state.
rpc transitionToObserver(.hadoop.common.TransitionToObserverRequestProto) returns (.hadoop.common.TransitionToObserverResponseProto);
public abstract void getServiceStatus(org.apache.hadoop.thirdparty.protobuf.RpcController controller, HAServiceProtocolProtos.GetServiceStatusRequestProto request, org.apache.hadoop.thirdparty.protobuf.RpcCallback<HAServiceProtocolProtos.GetServiceStatusResponseProto> done)
Get the current status of the service.
rpc getServiceStatus(.hadoop.common.GetServiceStatusRequestProto) returns (.hadoop.common.GetServiceStatusResponseProto);
public static final org.apache.hadoop.thirdparty.protobuf.Descriptors.ServiceDescriptor getDescriptor()
public final org.apache.hadoop.thirdparty.protobuf.Descriptors.ServiceDescriptor getDescriptorForType()
getDescriptorForType
in interface org.apache.hadoop.thirdparty.protobuf.Service
public final void callMethod(org.apache.hadoop.thirdparty.protobuf.Descriptors.MethodDescriptor method, org.apache.hadoop.thirdparty.protobuf.RpcController controller, org.apache.hadoop.thirdparty.protobuf.Message request, org.apache.hadoop.thirdparty.protobuf.RpcCallback<org.apache.hadoop.thirdparty.protobuf.Message> done)
callMethod
in interface org.apache.hadoop.thirdparty.protobuf.Service
public final org.apache.hadoop.thirdparty.protobuf.Message getRequestPrototype(org.apache.hadoop.thirdparty.protobuf.Descriptors.MethodDescriptor method)
getRequestPrototype
in interface org.apache.hadoop.thirdparty.protobuf.Service
public final org.apache.hadoop.thirdparty.protobuf.Message getResponsePrototype(org.apache.hadoop.thirdparty.protobuf.Descriptors.MethodDescriptor method)
getResponsePrototype
in interface org.apache.hadoop.thirdparty.protobuf.Service
public static HAServiceProtocolProtos.HAServiceProtocolService.Stub newStub(org.apache.hadoop.thirdparty.protobuf.RpcChannel channel)
public static HAServiceProtocolProtos.HAServiceProtocolService.BlockingInterface newBlockingStub(org.apache.hadoop.thirdparty.protobuf.BlockingRpcChannel channel)
Copyright © 2008–2020 Apache Software Foundation. All rights reserved.