Package org.apache.hadoop.hdfs.notifier

Examples of org.apache.hadoop.hdfs.notifier.InvalidClientIdException


    Set<Long> clientsForEvent;
    ClientData clientData = clientsData.get(clientId);
   
    if (clientData == null) {
      LOG.warn("subscribe client called with invalid id " + clientId);
      throw new InvalidClientIdException();
    }
   
    LOG.info("Subscribing client " + clientId + " to " +
        NotifierUtils.asString(event) + " from txId " + txId);
View Full Code Here


    Set<Long> clientsForEvent;
    ClientData clientData = clientsData.get(clientId);
   
    if (clientData == null) {
      LOG.warn("subscribe client called with invalid id " + clientId);
      throw new InvalidClientIdException();
    }
   
    LOG.info("Unsubscribing client " + clientId + " from " +
        NotifierUtils.asString(event));
   
View Full Code Here

    }
   
    ClientData clientData = clientsData.get(clientId);
    if (clientData == null) {
      LOG.error("Missing the client data for client id: " + clientId);
      throw new InvalidClientIdException("Missing the client data");
    }
   
    // Store the notifications in the queue for this client
    serverHistory.addNotificationsToQueue(event, txId, clientData.queue);
  }
View Full Code Here

  public void subscribe(long clientId, NamespaceEvent subscribedEvent,
      long txId) throws InvalidClientIdException, TransactionIdTooOldException,
      TException {
    core.getMetrics().subscribeCalls.inc();
    if (!core.isRegistered(clientId)) {
      throw new InvalidClientIdException("Invalid client id: " + clientId);
    }
    core.subscribeClient(clientId, subscribedEvent, txId);
  }
View Full Code Here

  @Override
  public void unsubscribe(long clientId, NamespaceEvent subscribedEvent)
      throws InvalidClientIdException, TException, ClientNotSubscribedException {
    core.getMetrics().unsubscribeCalls.inc();
    if (!core.isRegistered(clientId)) {
      throw new InvalidClientIdException("Invalid client id: " + clientId);
    }
   
    core.unsubscribeClient(clientId, subscribedEvent);
  }
View Full Code Here

  public void unregisterClient(long clientId) throws InvalidClientIdException,
      TException {
    core.getMetrics().unregisterClientCalls.inc();
    if (!core.removeClient(clientId)) {
      LOG.warn("Invalid request to remove client with id: " + clientId);
      throw new InvalidClientIdException("Invalid client id: " + clientId);
    }
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hdfs.notifier.InvalidClientIdException

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.