/src/java/org/apache/cassandra/thrift/ThriftServer.java

http://github.com/apache/cassandra · Java · 120 lines · 83 code · 15 blank · 22 comment · 5 complexity · 602ec2ea190b4ac417ed7f972a34ab8d MD5 · raw file

  1. /*
  2. * Licensed to the Apache Software Foundation (ASF) under one
  3. * or more contributor license agreements. See the NOTICE file
  4. * distributed with this work for additional information
  5. * regarding copyright ownership. The ASF licenses this file
  6. * to you under the Apache License, Version 2.0 (the
  7. * "License"); you may not use this file except in compliance
  8. * with the License. You may obtain a copy of the License at
  9. *
  10. * http://www.apache.org/licenses/LICENSE-2.0
  11. *
  12. * Unless required by applicable law or agreed to in writing, software
  13. * distributed under the License is distributed on an "AS IS" BASIS,
  14. * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  15. * See the License for the specific language governing permissions and
  16. * limitations under the License.
  17. */
  18. package org.apache.cassandra.thrift;
  19. import java.net.InetAddress;
  20. import java.net.InetSocketAddress;
  21. import org.slf4j.Logger;
  22. import org.slf4j.LoggerFactory;
  23. import org.apache.cassandra.service.CassandraDaemon;
  24. import org.apache.cassandra.config.DatabaseDescriptor;
  25. import org.apache.thrift.server.TServer;
  26. import org.apache.thrift.transport.TFramedTransport;
  27. public class ThriftServer implements CassandraDaemon.Server
  28. {
  29. private static Logger logger = LoggerFactory.getLogger(ThriftServer.class);
  30. final static String SYNC = "sync";
  31. final static String ASYNC = "async";
  32. final static String HSHA = "hsha";
  33. private final InetAddress address;
  34. private final int port;
  35. private volatile ThriftServerThread server;
  36. public ThriftServer(InetAddress address, int port)
  37. {
  38. this.address = address;
  39. this.port = port;
  40. }
  41. public void start()
  42. {
  43. if (server == null)
  44. {
  45. server = new ThriftServerThread(address, port);
  46. server.start();
  47. }
  48. }
  49. public void stop()
  50. {
  51. if (server != null)
  52. {
  53. server.stopServer();
  54. try
  55. {
  56. server.join();
  57. }
  58. catch (InterruptedException e)
  59. {
  60. logger.error("Interrupted while waiting thrift server to stop", e);
  61. }
  62. server = null;
  63. }
  64. }
  65. public boolean isRunning()
  66. {
  67. return server != null;
  68. }
  69. /**
  70. * Simple class to run the thrift connection accepting code in separate
  71. * thread of control.
  72. */
  73. private static class ThriftServerThread extends Thread
  74. {
  75. private TServer serverEngine;
  76. public ThriftServerThread(InetAddress listenAddr, int listenPort)
  77. {
  78. // now we start listening for clients
  79. logger.info(String.format("Binding thrift service to %s:%s", listenAddr, listenPort));
  80. TServerFactory.Args args = new TServerFactory.Args();
  81. args.tProtocolFactory = new TBinaryProtocol.Factory(true, true, DatabaseDescriptor.getThriftMaxMessageLength());
  82. args.addr = new InetSocketAddress(listenAddr, listenPort);
  83. args.cassandraServer = new CassandraServer();
  84. args.processor = new Cassandra.Processor(args.cassandraServer);
  85. args.keepAlive = DatabaseDescriptor.getRpcKeepAlive();
  86. args.sendBufferSize = DatabaseDescriptor.getRpcSendBufferSize();
  87. args.recvBufferSize = DatabaseDescriptor.getRpcRecvBufferSize();
  88. int tFramedTransportSize = DatabaseDescriptor.getThriftFramedTransportSize();
  89. logger.info("Using TFramedTransport with a max frame size of {} bytes.", tFramedTransportSize);
  90. args.inTransportFactory = new TFramedTransport.Factory(tFramedTransportSize);
  91. args.outTransportFactory = new TFramedTransport.Factory(tFramedTransportSize);
  92. serverEngine = new TServerCustomFactory(DatabaseDescriptor.getRpcServerType()).buildTServer(args);
  93. }
  94. public void run()
  95. {
  96. logger.info("Listening for thrift clients...");
  97. serverEngine.serve();
  98. }
  99. public void stopServer()
  100. {
  101. logger.info("Stop listening to thrift clients");
  102. serverEngine.stop();
  103. }
  104. }
  105. }