public class NetworkEnvironment extends Object
TaskManager
instance. The network environment contains
the data structures that keep track of all intermediate results and all data exchanges.Constructor and Description |
---|
NetworkEnvironment(int numBuffers,
int memorySegmentSize,
int partitionRequestInitialBackoff,
int partitionRequestMaxBackoff,
int networkBuffersPerChannel,
int extraNetworkBuffersPerGate,
boolean enableCreditBased) |
NetworkEnvironment(NetworkBufferPool networkBufferPool,
ConnectionManager connectionManager,
ResultPartitionManager resultPartitionManager,
TaskEventDispatcher taskEventDispatcher,
KvStateRegistry kvStateRegistry,
KvStateServer kvStateServer,
KvStateClientProxy kvStateClientProxy,
IOManager.IOMode defaultIOMode,
int partitionRequestInitialBackoff,
int partitionRequestMaxBackoff,
int networkBuffersPerChannel,
int extraNetworkBuffersPerGate,
boolean enableCreditBased) |
Modifier and Type | Method and Description |
---|---|
TaskKvStateRegistry |
createKvStateTaskRegistry(JobID jobId,
JobVertexID jobVertexId) |
ConnectionManager |
getConnectionManager() |
IOManager.IOMode |
getDefaultIOMode() |
KvStateClientProxy |
getKvStateProxy() |
KvStateRegistry |
getKvStateRegistry() |
KvStateServer |
getKvStateServer() |
NetworkBufferPool |
getNetworkBufferPool() |
int |
getPartitionRequestInitialBackoff() |
int |
getPartitionRequestMaxBackoff() |
ResultPartitionManager |
getResultPartitionManager() |
TaskEventDispatcher |
getTaskEventDispatcher() |
boolean |
isCreditBased() |
boolean |
isShutdown() |
void |
registerTask(Task task) |
void |
setupInputGate(SingleInputGate gate) |
void |
setupPartition(ResultPartition partition) |
void |
shutdown()
Tries to shut down all network I/O components.
|
void |
start() |
void |
unregisterTask(Task task) |
public NetworkEnvironment(int numBuffers, int memorySegmentSize, int partitionRequestInitialBackoff, int partitionRequestMaxBackoff, int networkBuffersPerChannel, int extraNetworkBuffersPerGate, boolean enableCreditBased)
public NetworkEnvironment(NetworkBufferPool networkBufferPool, ConnectionManager connectionManager, ResultPartitionManager resultPartitionManager, TaskEventDispatcher taskEventDispatcher, KvStateRegistry kvStateRegistry, KvStateServer kvStateServer, KvStateClientProxy kvStateClientProxy, IOManager.IOMode defaultIOMode, int partitionRequestInitialBackoff, int partitionRequestMaxBackoff, int networkBuffersPerChannel, int extraNetworkBuffersPerGate, boolean enableCreditBased)
public ResultPartitionManager getResultPartitionManager()
public TaskEventDispatcher getTaskEventDispatcher()
public ConnectionManager getConnectionManager()
public NetworkBufferPool getNetworkBufferPool()
public IOManager.IOMode getDefaultIOMode()
public int getPartitionRequestInitialBackoff()
public int getPartitionRequestMaxBackoff()
public boolean isCreditBased()
public KvStateRegistry getKvStateRegistry()
public KvStateServer getKvStateServer()
public KvStateClientProxy getKvStateProxy()
public TaskKvStateRegistry createKvStateTaskRegistry(JobID jobId, JobVertexID jobVertexId)
public void registerTask(Task task) throws IOException
IOException
@VisibleForTesting public void setupPartition(ResultPartition partition) throws IOException
IOException
@VisibleForTesting public void setupInputGate(SingleInputGate gate) throws IOException
IOException
public void unregisterTask(Task task)
public void start() throws IOException
IOException
public void shutdown()
public boolean isShutdown()
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.