public abstract class MapOutputTracker extends Object implements Logging
Constructor and Description |
---|
MapOutputTracker(SparkConf conf) |
Modifier and Type | Method and Description |
---|---|
static MapStatus[] |
deserializeMapStatuses(byte[] bytes) |
long |
getEpoch()
Called to get current epoch number.
|
scala.Tuple2<BlockManagerId,Object>[] |
getServerStatuses(int shuffleId,
int reduceId)
Called from executors to get the server URIs and output sizes of the map outputs of
a given shuffle.
|
static byte[] |
serializeMapStatuses(MapStatus[] statuses) |
void |
stop()
Stop the tracker.
|
akka.actor.ActorRef |
trackerActor()
Set to the MapOutputTrackerActor living on the driver.
|
void |
unregisterShuffle(int shuffleId)
Unregister shuffle data.
|
void |
updateEpoch(long newEpoch)
Called from executors to update the epoch number, potentially clearing old outputs
because of a fetch failure.
|
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
public MapOutputTracker(SparkConf conf)
public static byte[] serializeMapStatuses(MapStatus[] statuses)
public static MapStatus[] deserializeMapStatuses(byte[] bytes)
public akka.actor.ActorRef trackerActor()
public scala.Tuple2<BlockManagerId,Object>[] getServerStatuses(int shuffleId, int reduceId)
public long getEpoch()
public void updateEpoch(long newEpoch)
public void unregisterShuffle(int shuffleId)
public void stop()