public class PluginEndpoint extends Object implements IsolatedRpcEndpoint, Logging
Constructor and Description |
---|
PluginEndpoint(scala.collection.immutable.Map<String,DriverPlugin> plugins,
org.apache.spark.rpc.RpcEnv rpcEnv) |
Modifier and Type | Method and Description |
---|---|
scala.PartialFunction<Object,scala.runtime.BoxedUnit> |
receive()
Process messages from
RpcEndpointRef.send or RpcCallContext.reply . |
scala.PartialFunction<Object,scala.runtime.BoxedUnit> |
receiveAndReply(RpcCallContext context)
Process messages from
RpcEndpointRef.ask . |
org.apache.spark.rpc.RpcEnv |
rpcEnv()
The
RpcEnv that this RpcEndpoint is registered to. |
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
threadCount
onConnected, onDisconnected, onError, onNetworkError, onStart, onStop, self, stop
initializeForcefully, initializeLogging, initializeLogIfNecessary, initializeLogIfNecessary, isTraceEnabled, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
public PluginEndpoint(scala.collection.immutable.Map<String,DriverPlugin> plugins, org.apache.spark.rpc.RpcEnv rpcEnv)
public scala.PartialFunction<Object,scala.runtime.BoxedUnit> receive()
RpcEndpoint
RpcEndpointRef.send
or RpcCallContext.reply
. If receiving a
unmatched message, SparkException
will be thrown and sent to onError
.receive
in interface RpcEndpoint
public scala.PartialFunction<Object,scala.runtime.BoxedUnit> receiveAndReply(RpcCallContext context)
RpcEndpoint
RpcEndpointRef.ask
. If receiving a unmatched message,
SparkException
will be thrown and sent to onError
.receiveAndReply
in interface RpcEndpoint
context
- (undocumented)public org.apache.spark.rpc.RpcEnv rpcEnv()
RpcEndpoint
RpcEnv
that this RpcEndpoint
is registered to.rpcEnv
in interface RpcEndpoint