BftProtocolManager.java

/*
 * Copyright ConsenSys AG.
 *
 * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
 * the License. You may obtain a copy of the License at
 *
 * http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on
 * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the
 * specific language governing permissions and limitations under the License.
 *
 * SPDX-License-Identifier: Apache-2.0
 */
package org.hyperledger.besu.consensus.common.bft.protocol;

import org.hyperledger.besu.consensus.common.bft.BftEventQueue;
import org.hyperledger.besu.consensus.common.bft.events.BftEvent;
import org.hyperledger.besu.consensus.common.bft.events.BftEvents;
import org.hyperledger.besu.consensus.common.bft.network.PeerConnectionTracker;
import org.hyperledger.besu.datatypes.Address;
import org.hyperledger.besu.ethereum.p2p.network.ProtocolManager;
import org.hyperledger.besu.ethereum.p2p.peers.Peer;
import org.hyperledger.besu.ethereum.p2p.rlpx.connections.PeerConnection;
import org.hyperledger.besu.ethereum.p2p.rlpx.wire.Capability;
import org.hyperledger.besu.ethereum.p2p.rlpx.wire.Message;
import org.hyperledger.besu.ethereum.p2p.rlpx.wire.MessageData;
import org.hyperledger.besu.ethereum.p2p.rlpx.wire.messages.DisconnectMessage.DisconnectReason;

import java.util.Arrays;
import java.util.List;

import org.slf4j.Logger;
import org.slf4j.LoggerFactory;

/** The Bft protocol manager. */
public class BftProtocolManager implements ProtocolManager {
  private static final Logger LOG = LoggerFactory.getLogger(BftProtocolManager.class);

  private final BftEventQueue bftEventQueue;
  private final PeerConnectionTracker peers;
  private final Capability supportedCapability;
  private final String subProtocolName;

  /**
   * Constructor for the ibft protocol manager
   *
   * @param bftEventQueue Entry point into the ibft event processor
   * @param peers Used to track all connected IBFT peers.
   * @param supportedCapability The capability offered by this protocol manager
   * @param subProtocolName The name of the protocol being supported
   */
  public BftProtocolManager(
      final BftEventQueue bftEventQueue,
      final PeerConnectionTracker peers,
      final Capability supportedCapability,
      final String subProtocolName) {
    this.bftEventQueue = bftEventQueue;
    this.peers = peers;
    this.supportedCapability = supportedCapability;
    this.subProtocolName = subProtocolName;
  }

  @Override
  public String getSupportedProtocol() {
    return subProtocolName;
  }

  @Override
  public List<Capability> getSupportedCapabilities() {
    return Arrays.asList(supportedCapability);
  }

  @Override
  public void stop() {}

  @Override
  public void awaitStop() throws InterruptedException {}

  /**
   * This function is called by the P2P framework when an "IBF" message has been received. This
   * function is responsible for:
   *
   * <ul>
   *   <li>Determining if the message was from a current validator (discard if not)
   *   <li>Determining if the message received was for the 'current round', discarding if old and
   *       buffering for the future if ahead of current state.
   *   <li>If the received message is otherwise valid, it is sent to the state machine which is
   *       responsible for determining how to handle the message given its internal state.
   * </ul>
   *
   * @param cap The capability under which the message was transmitted.
   * @param message The message to be decoded.
   */
  @Override
  public void processMessage(final Capability cap, final Message message) {
    final MessageData messageData = message.getData();
    final int code = messageData.getCode();
    final Address address = message.getConnection().getPeerInfo().getAddress();
    LOG.trace("Process message {}, {}, from = {}", cap, code, address);

    final BftEvent messageEvent = BftEvents.fromMessage(message);
    bftEventQueue.add(messageEvent);
  }

  @Override
  public void handleNewConnection(final PeerConnection peerConnection) {
    peers.add(peerConnection);
  }

  @Override
  public boolean shouldConnect(final Peer peer, final boolean incoming) {
    return false; // for now the EthProtocolManager takes care of this
  }

  @Override
  public void handleDisconnect(
      final PeerConnection peerConnection,
      final DisconnectReason disconnectReason,
      final boolean initiatedByPeer) {
    peers.remove(peerConnection);
  }

  @Override
  public int getHighestProtocolVersion() {
    return supportedCapability.getVersion();
  }
}