Click here to Skip to main content
15,881,172 members
Articles / Desktop Programming / Win32
Article

.NET and Delphi Inter-Process Communication via Named Pipes

Rate me:
Please Sign up or sign in to vote.
5.00/5 (4 votes)
12 Dec 2014CPOL7 min read 29.7K   1.4K   15   1
Calling native methods from .NET application via standard Windows Named Pipes

Introduction

Let's imagine that we have legacy code written in Delphi that does some sort of sophisticated data processing. The code is 32-bit and not thread safe, meaning it can serve only one request at a time. Our task would be to extend functionality of the existing code by introducing a .NET wrapper around it, possibly exposing functionality via WCF, or some other means usable in the .NET world, and implement efficient communication mechanism between the two. We would also need to have our .NET wrapper to be 64-bit and potentially support parallel processing.

The latter two requirements dictate that both the wrapper and Delphi part must be compiled into separate executables, because the alternative of sharing single process boundaries (communicating via P/Invoke, for example) is not an option in this case: 32-bit DLL cannot live inside 64-bit process, and the parallelism cannot be achieved within single process because our Delphi code is not thread-safe.

There are many ways to organize inter-process communication (IPC). However, in this article, we will focus on standard Windows Named Pipes. The attached solution consists of two projects: .NET and Delphi console applications. In order to simulate data processing, we will implement 4 arithmetic operations in the Delphi project: addition, subtraction, multiplication, and division. The .NET application will serve the purpose of calling one of those 4 operations. Since we are focusing on Named Pipes inter-process communication aspect, we will not cover other issues like security, automatic message serialization, automatic call dispatch, or supporting parallelism.

Message Format

In the current solution, two processes communicate by sending string messages in the form of XML. Here is an example of message XML describing request of multiplying X and Y variables:

XML
<Message Name="Mult">
  <Data Key="X">3</Data>
  <Data Key="Y">5</Data>
</Message>

The resulting message would be:

XML
<Message Name="Result">
  <Data Key="Result">15</Data>
</Message>

If calculation, for some reason, produces exception, the message would look as follows:

XML
<Message IsError="1" ErrorCode="EZeroDivide" ErrorText="Floating point division by zero"/>

Both the caller and callee must be aware of the format of messages and agree to follow the protocol. That said, we can describe any method with any number of arguments, send it through a pipe, and expect results back from the channel including any exceptions that might occur down the road. Although the format of messages is more verbose than it could be, it is acceptable for our demo purposes.

The message structure is encapsulated in both .NET and Delphi projects in PipeMessage and TPipeMessage classes respectively.

High Level Protocol

As mentioned above, there are two console applications in the solution. If we execute the Delphi application, it will not do anything unless we supply a command-line argument with the name of Pipe Channel as follows: pipe=<name_of_pipe_channel>. This name is an arbitrary string representing the name of the channel we expect to communicate through. If the channel name is specified, Delphi application will instantiate a Pipe Server and start listening for commands.

The calling .NET application, on the other hand, defines a channel named "interop.demo" and attempts to send all requests through that channel. After sending a request, it might either get a result, if Delphi application is already instantiated and listening to that channel, or an exception named PipeServerNotFoundException, indicating that no such channel exists yet. In the latter case while handling this exception, it will attempt to instantiate the Delphi executable passing the channel name as command-line argument, and reissue the same request one more time.

C#
public sealed class PipeInteropDispatcher
{
  private const string c_pipeName = @"interop.demo";
  private const string c_pipeServerName = "NamedPipesInteropDelphi.exe";

  private static async Task CreatePipeServer(string pipeName)
  {
    try
    {
      Process.Start(c_pipeServerName, "pipe=" + pipeName);
      await new PipeClient(pipeName).WaitForPipe(10000);
    }
    catch (Exception ex)
    {
      throw new InvalidOperationException(string.Format(
        "Unable to instantiate Server: {0}", ex.Message), ex);
    }
  }

  public static async Task<pipemessage> ProcessRequestAsync(PipeMessage request)
  {
    var needInstance = false;
    var result = default (PipeMessage);
    var pipe = new PipeClient(c_pipeName);

    try
    {
      result = await pipe.ProcessRequest(request);
    }
    catch (PipeServerBrokenPipeException)
    {
      needInstance = true;
    }
    catch (PipeServerNotFoundException)
    {
      needInstance = true;
    }

    if (needInstance)
    {
      await CreatePipeServer(c_pipeName);
      result = await pipe.ProcessRequest(request);
    }

    return result;
  }
}</pipemessage>

With these rules in place, we gain the following benefits:

  1. Ease of debugging - we can run Delphi application from Delphi Debugger specifying proper pipe channel name as command line argument.
  2. Delphi process can terminate itself (e.g. on idling timeout) at any time without breaking the system because any subsequent request coming through the pipe would fail with appropriate exception and the calling process would re-instantiate the app. In fact, we can forcibly terminate Delhi process from Task Manager at any time with the same effect.
  3. We can implement parallelism functionality on top of existing architecture (not presented in current solution) by maintaining a pool of pipe channel names that we can use to send messages trough in parallel fashion.

Client Side (.NET App)

Depending on the user's input, we send an appropriate method name as well as X and Y variables to the following method:

C#
private static async Task<decimal> CalcAsync(string method, decimal x, decimal y)
{
  var args = new Dictionary<string, string>
  {
    {"X", x.ToString(CultureInfo.InvariantCulture)},
    {"Y", y.ToString(CultureInfo.InvariantCulture)}
  };
  var result = await PipeInteropDispatcher.ProcessRequestAsync(new PipeMessage(method, args));
  return decimal.Parse(result["Result"]);
}

We simply create Dictionary<string, string> object, populate it with input arguments, and hand it over to the PipeInteropDispatcher for further processing.

PipeClient class plays central role in sending messages through the pipe channel. Internally, it is using standard .NET NamedPipeClientStream class to communicate with native Windows Named Pipes API. In order to efficiently transfer large messages over the channel, we are sending them in chunks of 4KB maximum. So every request larger than 4KB gets broken down into series of smaller messages that are sequentially being streamed out through the channel.

In order to coordinate original message size with counterpart process, the first 4 bytes of streaming data will contain an Int32 number representing the size of that original message. This way, the process receiving the message will read the first 4 bytes from the stream and use that value to continue reading data until the entire X bytes of the message are read.

C#
public sealed class PipeClient
{
  private readonly string m_serverName;

  private readonly string m_pipeName;

  public PipeClient(string pipeName)
    : this(".", pipeName) { }

  public PipeClient(string serverName, string pipeName)
  {
    m_serverName = serverName;
    m_pipeName = pipeName;
  }

  private static async Task<bool> CopyStream(Stream src, Stream dst, int bytes, int bufferSize)
  {
    var buffer = new byte[bufferSize];
    int read;
    while (bytes > 0 && 
    (read = await src.ReadAsync(buffer, 0, Math.Min(buffer.Length, bytes))) > 0)
    {
      await dst.WriteAsync(buffer, 0, read);
      bytes -= read;
    }
    return bytes == 0;
  }

  private async Task<string> ProcessRequest(string message)
  {
    var dataBuffer = Encoding.ASCII.GetBytes(message);
    var dataSize = dataBuffer.Length;

    if (dataSize == 0)
      return null;

    using (var pipe = new NamedPipeClientStream(m_serverName, m_pipeName, 
      PipeDirection.InOut, PipeOptions.Asynchronous | PipeOptions.WriteThrough))
    {
      try
      {
        await Task.Run(() => pipe.Connect(500));
      }
      catch (TimeoutException e)
      {
        throw new PipeServerNotFoundException(e.Message, e);
      }

      pipe.ReadMode = PipeTransmissionMode.Message;

      const int cBufferSize = 4096;

      try
      {
        var dataSizeBuffer = BitConverter.GetBytes(dataSize);
        await pipe.WriteAsync(dataSizeBuffer, 0, dataSizeBuffer.Length);
        using (var stream = new MemoryStream(dataBuffer))
          await CopyStream(stream, pipe, dataSize, cBufferSize);
        await pipe.FlushAsync();

        dataSizeBuffer = new byte[sizeof(Int32)];
        var bytesRead = await pipe.ReadAsync(dataSizeBuffer, 0, sizeof(Int32));
        if (bytesRead <= 0)
          throw new PipeServerBrokenPipeException();

        dataSize = BitConverter.ToInt32(dataSizeBuffer, 0);
        if (dataSize <= 0)
          return null;

        using (var stream = new MemoryStream(dataSize))
        {
          if (!await CopyStream(pipe, stream, dataSize, cBufferSize))
            throw new PipeServerBrokenPipeException();
          var resultBuffer = stream.GetBuffer();
          var decoder = Encoding.ASCII.GetDecoder();
          var charCount = decoder.GetCharCount(resultBuffer, 0, dataSize, false);
          var charResultBuffer = new char[charCount];
          decoder.GetChars(resultBuffer, 0, dataSize, charResultBuffer, 0, false);
          decoder.Reset();
          return new string(charResultBuffer);
        }
      }
      catch (IOException ex)
      {
        // Console.WriteLine(ex.Message);
        // NOTE: This is not reliable, but will do for now
        if (ex.Message.Contains("Pipe is broken"))
          throw new PipeServerBrokenPipeException();
        throw;
      }
    }
  }

  public async Task<PipeMessage> ProcessRequest(PipeMessage message)
  {
    var resultMessage = await ProcessRequest(message.ToString());
    var result = new PipeMessage(resultMessage);
    if (result.IsError)
      throw new PipeServerException(result.ErrorCode, result.ErrorText);
    return result;
  }

  public async Task WaitForPipe(int timeout)
  {
    await Task.Run(() =>
    {
      using (var pipe = new NamedPipeClientStream(m_serverName, m_pipeName, 
        PipeDirection.InOut, PipeOptions.Asynchronous | PipeOptions.WriteThrough))
        pipe.Connect(timeout);
    });
  }
}

Server Side (Delphi App)

Here is the list of classes used on the server side to support Named Pipes communication:

  1. TNamedPipeServer. This class encapsulates low level interaction with native Windows Named Pipes API.
  2. TPipeMessage. Represents an object wrapper around XML message.
  3. TCalcPipeServer. Inherits from TNamedPipeServer and overrides its DispatchMessage method passing request to a Dispatcher.
  4. TCalcRequestDispatcher. Encapsulates method dispatching functionality converting incoming XML messages into actual method calls, and packing results back to resulting XML messages.
  5. TCalcProcessor. A helper class containing actual implementation of business logic (4 arithmetic operations in our case).

When Delphi App starts, it will read the pipe channel name from command line and instantiate a Pipe Server passing that channel name to it. The Pipe Server instance will create the channel and start listening to incoming requests until user presses ENTER or application gets shut down some other way.

Upon receiving a message from channel, the Pipe Server will hand it over to a DispatchMessage virtual method, which is overridden by TCalcPipeServer:

procedure TCalcPipeServer.DispatchMessage(ARequestStream, AResponseStream: TStream);
var
  lData: string;
begin
  SetLength(lData, ARequestStream.Size);
  ARequestStream.Read(lData[1], Length(lData));
  lData := RequestDispatcher.ProcessRequest(lData);
  AResponseStream.Write(lData[1], Length(lData));
end;

RequestDispatcher in this case is represented by TCalcRequestDispatcher class that transforms XML requests into actual method calls and returns result back as XML string:

function TCalcRequestDispatcher.InternalProcessRequest(const ARequest: string): string;
var
  lRequest: TPipeMessage;
  X, Y, lResult: Double;
begin
  Result := '';
  lRequest := TPipeMessage.Create(ARequest);
  try
    if lRequest.Name = 'Add' then
    begin
      X := StrToFloat(lRequest.Data['X']);
      Y := StrToFloat(lRequest.Data['Y']);
      lResult := TCalcProcessor.Add(X, Y);
      Result := TPipeMessage.MakeMessage('Result', ['Result'], [FloatToStr(lResult)]);
    end
    else if lRequest.Name = 'Subtract' then
    begin
      X := StrToFloat(lRequest.Data['X']);
      Y := StrToFloat(lRequest.Data['Y']);
      lResult := TCalcProcessor.Subtract(X, Y);
      Result := TPipeMessage.MakeMessage('Result', ['Result'], [FloatToStr(lResult)]);
    end
    else if lRequest.Name = 'Mult' then
    begin
      X := StrToFloat(lRequest.Data['X']);
      Y := StrToFloat(lRequest.Data['Y']);
      lResult := TCalcProcessor.Mult(X, Y);
      Result := TPipeMessage.MakeMessage('Result', ['Result'], [FloatToStr(lResult)]);
    end
    else if lRequest.Name = 'Div' then
    begin
      X := StrToFloat(lRequest.Data['X']);
      Y := StrToFloat(lRequest.Data['Y']);
      lResult := TCalcProcessor.Divide(X, Y);
      Result := TPipeMessage.MakeMessage('Result', ['Result'], [FloatToStr(lResult)]);
    end
    else if lRequest.Name = 'ExitProcess' then
    begin
      ExitProcess(0);
    end
    else if lRequest.Name = 'Ping' then
    begin
      // do nothing;
    end
    else
      raise Exception.CreateFmt('Unknown request: %s', [lRequest.Name]);
  finally
    lRequest.Free;
  end;
end;

Pipe Server Implementation

TNamedPipeServer class accepts a string argument in its constructor representing pipe channel name argument and internally creates a Listener Thread, a Message Queue, and a Worker Thread.

The Listener is represented by TPipeListenerThread class. Its main job is to constantly monitor the Pipe Channel for incoming requests, and sending them over to the Message Queue. The latter is represented by TThreadQueue class, a thread-safe implementation of a Queue with blocking behavior, meaning that the pushing thread will get blocked if the queue size has reached maximum number of messages, and the popping thread will get blocked if there are no elements in the queue. And finally, the Working Thread is represented by TPipeWorkerThread class, which is continuously extracting messages from the Queue and handing them over to the Message Handler.

The Message Handler is represented by TPipeMessageHandler class and implements stream read/write logic. The Message Handler uses given handle to the Pipe Channel and starts reading from it. Once the message is read, it is being passed to the Dispatcher (that we already described), and the final result is being written back to the stream according to the protocol rules. The source code of message streaming is presented below:

procedure TPipeMessageHandler.Execute;
var
  lReadStream, lWriteStream: TMemoryStream;
  lBytesRead, lBytesWritten: DWORD;
  lSuccess: BOOL;
  lDataSize, lBufferSize: Integer;
  lBuffer: PChar;
begin
  lBufferSize := FServer.BufferSize;
  GetMem(lBuffer, lBufferSize);
  lReadStream := TMemoryStream.Create;
  try
    try
      lSuccess := ReadFile(fPipeHandle, lDataSize, SizeOf(lDataSize), lBytesRead, nil);

      if not lSuccess then
      begin
        if GetLastError = ERROR_BROKEN_PIPE then
          Exit
        else
          RaiseLastOSError;
      end;

      while lDataSize > 0 do
      begin
        lSuccess := ReadFile(fPipeHandle, lBuffer^, lBufferSize, lBytesRead, nil);

        if not lSuccess and (GetLastError <> ERROR_MORE_DATA) then
          RaiseLastOSError;

        if lBytesRead > 0 then
          lReadStream.Write(lBuffer^, lBytesRead);

        Dec(lDataSize, lBytesRead);
      end;

      if not lSuccess then
        RaiseLastOSError;

      if lReadStream.Size > 0 then
      begin
        lReadStream.Position := 0;
        lWriteStream := TMemoryStream.Create;
        try
          FServer.DispatchMessage(lReadStream, lWriteStream);
          lReadStream.Position := 0;
          lReadStream.SetSize(0);
          lWriteStream.Position := 0;

          lDataSize := lWriteStream.Size;
          lSuccess := WriteFile(fPipeHandle, lDataSize, SizeOf(lDataSize), lBytesWritten, nil);

          if not lSuccess then
            RaiseLastOSError;

          while lDataSize > 0 do
          begin
            lBytesRead := lWriteStream.Read(lBuffer^, lBufferSize);
            Dec(lDataSize, lBytesRead);
            lSuccess := WriteFile(fPipeHandle, lBuffer^, lBytesRead, lBytesWritten, nil);

            if not lSuccess then
              RaiseLastOSError;
          end;
        finally
          lWriteStream.Free;
        end;
      end;
    except
      on E: EOSError do
      begin
        if not (E.ErrorCode in [ERROR_NO_DATA, ERROR_BROKEN_PIPE]) then
          raise;
      end;
    end;
  finally
    FreeMem(lBuffer);
    lReadStream.Free;
    FlushFileBuffers(FPipeHandle);
    DisconnectNamedPipe(FPipeHandle);
    CloseHandle(FPipeHandle);
  end;
end;

Summary

In this article, I tried to present one of the possible solutions of implementing inter-process communication between .NET Framework and legacy projects that might have certain restrictions, like thread-safety or not being able to run within 64-bit process. Sometimes it is very important to be able to initiate graceful migration from legacy code bases to .NET Framework without introducing major side effects and making transition as smooth as possible. Inter-process communication based on Named Pipes offers very efficient bi-directional protocol that might help in achieving those goals.

License

This article, along with any associated source code and files, is licensed under The Code Project Open License (CPOL)


Written By
United States United States
This member has not yet provided a Biography. Assume it's interesting and varied, and probably something to do with programming.

Comments and Discussions

 
GeneralMy vote of 5 Pin
alegn20-Apr-15 20:32
alegn20-Apr-15 20:32 

General General    News News    Suggestion Suggestion    Question Question    Bug Bug    Answer Answer    Joke Joke    Praise Praise    Rant Rant    Admin Admin   

Use Ctrl+Left/Right to switch messages, Ctrl+Up/Down to switch threads, Ctrl+Shift+Left/Right to switch pages.