Class RuncLibContainerManager

java.lang.Object
org.apache.storm.container.oci.OciContainerManager
org.apache.storm.container.oci.RuncLibContainerManager
All Implemented Interfaces:
ResourceIsolationInterface

public class RuncLibContainerManager extends OciContainerManager
  • Constructor Details

    • RuncLibContainerManager

      public RuncLibContainerManager()
  • Method Details

    • prepare

      public void prepare(Map<String,Object> conf) throws IOException
      Description copied from interface: ResourceIsolationInterface
      Called when starting up.
      Specified by:
      prepare in interface ResourceIsolationInterface
      Overrides:
      prepare in class OciContainerManager
      Parameters:
      conf - the cluster config
      Throws:
      IOException - on any error.
    • launchWorkerProcess

      public void launchWorkerProcess(String user, String topologyId, Map<String,Object> topoConf, int port, String workerId, List<String> command, Map<String,String> env, String logPrefix, ExitCodeCallback processExitCallback, File targetDir) throws IOException
      Description copied from interface: ResourceIsolationInterface
      After reserving resources for the worker (i.e. calling reserveResourcesForWorker), this function can be used to launch worker process.
      Parameters:
      user - the user who runs the command as
      topologyId - the Id of the topology
      topoConf - the topology configuration
      port - the port where the worker is on
      workerId - the Id of the worker
      command - the command to run
      env - the environment to run the command
      logPrefix - the prefix to include in the logs
      processExitCallback - a callback for when the process exits
      targetDir - the working directory to run the command in
      Throws:
      IOException - on I/O exception
    • getMemoryUsage

      public long getMemoryUsage(String user, String workerId, int port) throws IOException
      Description copied from interface: ResourceIsolationInterface
      Get the current memory usage of the a given worker.
      Parameters:
      user - the user that the worker is running as
      workerId - the id of the worker
      port - the port of the worker
      Returns:
      the amount of memory the worker is using in bytes or -1 if not supported
      Throws:
      IOException - on I/O exception
    • kill

      public void kill(String user, String workerId) throws IOException
      Description copied from interface: ResourceIsolationInterface
      Kill the given worker.
      Parameters:
      user - the user that the worker is running as
      workerId - the id of the worker to kill
      Throws:
      IOException - on I/O exception
    • forceKill

      public void forceKill(String user, String workerId) throws IOException
      Description copied from interface: ResourceIsolationInterface
      Kill the given worker forcefully.
      Parameters:
      user - the user that the worker is running as
      workerId - the id of the worker to kill
      Throws:
      IOException - on I/O exception
    • areAllProcessesDead

      public boolean areAllProcessesDead(String user, String workerId) throws IOException
      The container terminates if any process inside the container dies. So we only need to check if the initial process is alive or not.
      Parameters:
      user - the user that the processes are running as
      workerId - the id of the worker to kill
      Returns:
      true if all processes are dead; false otherwise
      Throws:
      IOException - on I/O exception
    • cleanup

      public void cleanup(String user, String workerId, int port) throws IOException
      Description copied from interface: ResourceIsolationInterface
      This function will be called when the worker needs to shutdown. This function should include logic to clean up after a worker is shutdown.
      Specified by:
      cleanup in interface ResourceIsolationInterface
      Overrides:
      cleanup in class OciContainerManager
      Parameters:
      user - the user of the worker
      workerId - worker id to shutdown and clean up after
      port - the port of the worker
      Throws:
      IOException
    • runProfilingCommand

      public boolean runProfilingCommand(String user, String workerId, List<String> command, Map<String,String> env, String logPrefix, File targetDir) throws IOException, InterruptedException
      Run profiling command in the container.
      Parameters:
      user - the user that the worker is running as
      workerId - the id of the worker
      command - the command to run. The profiler to be used is configured in worker-launcher.cfg.
      env - the environment to run the command
      logPrefix - the prefix to include in the logs
      targetDir - the working directory to run the command in
      Returns:
      true if the command succeeds, false otherwise.
      Throws:
      IOException - on I/O exception
      InterruptedException - if interrupted
    • isResourceManaged

      public boolean isResourceManaged()
      Description copied from interface: ResourceIsolationInterface
      Return true if resources are being managed. The DefaultResourceIsolationManager will have it return false since it doesn't really manage resources.
      Returns:
      true if resources are being managed.