Example usage for org.apache.hadoop.ipc VersionedProtocol interface-usage

List of usage examples for org.apache.hadoop.ipc VersionedProtocol interface-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.ipc VersionedProtocol interface-usage.

Usage

From source file org.apache.slider.api.SliderClusterProtocol.java

/**
 * Cluster protocol. This can currently act as a versioned IPC
 * endpoint or be relayed via protobuf
 */
@KerberosInfo(serverPrincipal = SliderXmlConfKeys.KEY_KERBEROS_PRINCIPAL)
public interface SliderClusterProtocol extends VersionedProtocol {

From source file org.apache.tez.common.TezTaskUmbilicalProtocol.java

/** Protocol that task child process uses to contact its parent process.  The
 * parent is a daemon which which polls the central master for a new map or
 * reduce task and runs it as a child process.  All communication between child
 * and parent is via this protocol. */
@TokenInfo(JobTokenSelector.class)
@InterfaceAudience.Private

From source file org.apache.tez.engine.api.Master.java

/**
 * {@link Master} represents the master controlling the {@link Task}. 
 */
@ProtocolInfo(protocolName = "Master", protocolVersion = 1)
public interface Master extends VersionedProtocol {

From source file org.cstor.cproc.cloudComputingFramework.CProcFrameworkProtocol.java

/** An client-datanode protocol for block recovery
 */
public interface CProcFrameworkProtocol extends VersionedProtocol {
    //public static final Log LOG = LogFactory.getLog(JobProtocol.class);

    public static final long versionID = 88L;

From source file org.goldenorb.OrbPartitionCommunicationProtocol.java

/**
 * This interface provides a protocol framework for OrbPartitions to send messages and vertices. In most cases
 * a class will implement the methods using Hadoop RPC for intercommunication between partitions.
 */
public interface OrbPartitionCommunicationProtocol extends VersionedProtocol {
    public static final long versionID = 0L;

From source file org.goldenorb.OrbPartitionManagerProtocol.java

/**
 * {@link OrbPartitionManagerProtocol} is the protocol used to facilitate communication between 
 * {@link OrbPartition} processes and {@link OrbPartitionManager}.
 */
public interface OrbPartitionManagerProtocol extends VersionedProtocol {
    public static final long versionID = 0L;

From source file org.goldenorb.OrbTrackerCommunicationProtocol.java

/**
 * {@link OrbTrackerCommunicationProtocol} is the protocol used to facilitate communication between 
 * running {@link OrbTracker} objects over Hadoop RPC.
 */
public interface OrbTrackerCommunicationProtocol extends VersionedProtocol {

From source file org.goldenorb.types.message.RPCProtocol.java

public interface RPCProtocol<M extends Message<W>, W extends Writable> extends VersionedProtocol {
    public static final long versionID = 1L;

    /**
     * 
     * @param  M msg

From source file org.sf.xrime.algorithms.pagerank.ZeroOutDegreeVertexRankCollector.java

/**
 * ZeroOutDegreeRankCollector is used by PageRankMapper to submit rank in vertex which out degree is zero.
 * The mechanism in org.apache.hadoop.ipc will be used here for communication between Mapper and JobTracker.
 * @author Cai Bin
 */
public interface ZeroOutDegreeVertexRankCollector extends VersionedProtocol {

From source file uk.ac.gla.terrier.probos.api.PBSClient.java

@ProtocolInfo(protocolName = "uk.ac.gla.terrier.probos.api.PBSClient", protocolVersion = 2)
@KerberosInfo(serverPrincipal = PConfiguration.KEY_CONTROLLER_PRINCIPAL)
@TokenInfo(ProbosDelegationTokenSelector.class)
/** Defines the publicly accessible protocol for {@link ControllerServer}. */
public interface PBSClient extends VersionedProtocol {