当前位置: 首页>>代码示例>>Java>>正文


Java ClientSocketChannelFactory类代码示例

本文整理汇总了Java中org.jboss.netty.channel.socket.ClientSocketChannelFactory的典型用法代码示例。如果您正苦于以下问题:Java ClientSocketChannelFactory类的具体用法?Java ClientSocketChannelFactory怎么用?Java ClientSocketChannelFactory使用的例子?那么, 这里精选的类代码示例或许可以为您提供帮助。


ClientSocketChannelFactory类属于org.jboss.netty.channel.socket包,在下文中一共展示了ClientSocketChannelFactory类的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Java代码示例。

示例1: BookKeeperClient

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
BookKeeperClient(DistributedLogConfiguration conf,
                 String name,
                 String zkServers,
                 ZooKeeperClient zkc,
                 String ledgersPath,
                 ClientSocketChannelFactory channelFactory,
                 HashedWheelTimer requestTimer,
                 StatsLogger statsLogger,
                 Optional<FeatureProvider> featureProvider) {
    this.conf = conf;
    this.name = name;
    this.zkServers = zkServers;
    this.ledgersPath = ledgersPath;
    this.passwd = conf.getBKDigestPW().getBytes(UTF_8);
    this.channelFactory = channelFactory;
    this.requestTimer = requestTimer;
    this.statsLogger = statsLogger;
    this.featureProvider = featureProvider;
    this.ownZK = null == zkc;
    if (null != zkc) {
        // reference the passing zookeeper client
        this.zkc = zkc;
    }
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:25,代码来源:BookKeeperClient.java

示例2: start

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
public synchronized void start() {
    final Executor bossPool = Executors.newCachedThreadPool();
    final Executor workerPool = Executors.newCachedThreadPool();
    bootstrap = new ServerBootstrap(new NioServerSocketChannelFactory(bossPool, workerPool));
    final ClientSocketChannelFactory clientSocketChannelFactory = new NioClientSocketChannelFactory(bossPool, workerPool);
    bootstrap.setOption("child.tcpNoDelay", true);
    allChannels = new DefaultChannelGroup("handler");

    bootstrap.setPipelineFactory(new ChannelPipelineFactory() {
        @Override
        public ChannelPipeline getPipeline() throws Exception {
            return Channels.pipeline(new FrontendHandler(allChannels, clientSocketChannelFactory, serverPool, statistics));
        }
    });

    log.info("Starting on port {}", port);
    acceptor = bootstrap.bind(new InetSocketAddress(port));

    if (acceptor.isBound()) {
        log.info("Server started successfully");
    }
}
 
开发者ID:iamseth,项目名称:tightrope,代码行数:23,代码来源:LoadBalancer.java

示例3: Fetcher

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
public Fetcher(URI uri, File file, ClientSocketChannelFactory factory) {
  this.uri = uri;
  this.file = file;

  String scheme = uri.getScheme() == null ? "http" : uri.getScheme();
  this.host = uri.getHost() == null ? "localhost" : uri.getHost();
  this.port = uri.getPort();
  if (port == -1) {
    if (scheme.equalsIgnoreCase("http")) {
      this.port = 80;
    } else if (scheme.equalsIgnoreCase("https")) {
      this.port = 443;
    }
  }

  bootstrap = new ClientBootstrap(factory);
  bootstrap.setOption("connectTimeoutMillis", 5000L); // set 5 sec
  bootstrap.setOption("receiveBufferSize", 1048576); // set 1M
  bootstrap.setOption("tcpNoDelay", true);

  ChannelPipelineFactory pipelineFactory = new HttpClientPipelineFactory(file);
  bootstrap.setPipelineFactory(pipelineFactory);
}
 
开发者ID:apache,项目名称:incubator-tajo,代码行数:24,代码来源:Fetcher.java

示例4: BlockingRpcClient

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
BlockingRpcClient(final Class<?> protocol,
                         final InetSocketAddress addr, ClientSocketChannelFactory factory)
    throws Exception {

  this.protocol = protocol;
  String serviceClassName = protocol.getName() + "$"
      + protocol.getSimpleName() + "Service";
  Class<?> serviceClass = Class.forName(serviceClassName);
  stubMethod = serviceClass.getMethod("newBlockingStub",
      BlockingRpcChannel.class);

  this.handler = new ClientChannelUpstreamHandler();
  pipeFactory = new ProtoPipelineFactory(handler,
      RpcResponse.getDefaultInstance());
  super.init(addr, pipeFactory, factory);
  rpcChannel = new ProxyRpcChannel();

  this.key = new RpcConnectionKey(addr, protocol, false);
}
 
开发者ID:apache,项目名称:incubator-tajo,代码行数:20,代码来源:BlockingRpcClient.java

示例5: AsyncRpcClient

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
AsyncRpcClient(final Class<?> protocol,
                      final InetSocketAddress addr, ClientSocketChannelFactory factory)
    throws Exception {

  this.protocol = protocol;
  String serviceClassName = protocol.getName() + "$"
      + protocol.getSimpleName() + "Service";
  Class<?> serviceClass = Class.forName(serviceClassName);
  stubMethod = serviceClass.getMethod("newStub", RpcChannel.class);

  this.handler = new ClientChannelUpstreamHandler();
  pipeFactory = new ProtoPipelineFactory(handler,
      RpcResponse.getDefaultInstance());
  super.init(addr, pipeFactory, factory);
  rpcChannel = new ProxyRpcChannel();
  this.key = new RpcConnectionKey(addr, protocol, true);
}
 
开发者ID:apache,项目名称:incubator-tajo,代码行数:18,代码来源:AsyncRpcClient.java

示例6: createClientChannelFactory

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
public static synchronized ClientSocketChannelFactory createClientChannelFactory(String name, int workerNum) {
  name = name + "-" + clientCount.incrementAndGet();
  if(LOG.isDebugEnabled()){
    LOG.debug("Create " + name + " ClientSocketChannelFactory. Worker:" + workerNum);
  }

  ThreadFactoryBuilder builder = new ThreadFactoryBuilder();
  ThreadFactory bossFactory = builder.setNameFormat(name + " Boss #%d").build();
  ThreadFactory workerFactory = builder.setNameFormat(name + " Worker #%d").build();

  NioClientBossPool bossPool = new NioClientBossPool(Executors.newCachedThreadPool(bossFactory), 1,
      new HashedWheelTimer(), ThreadNameDeterminer.CURRENT);
  NioWorkerPool workerPool = new NioWorkerPool(Executors.newCachedThreadPool(workerFactory), workerNum,
      ThreadNameDeterminer.CURRENT);

  return new NioClientSocketChannelFactory(bossPool, workerPool);
}
 
开发者ID:apache,项目名称:incubator-tajo,代码行数:18,代码来源:RpcChannelFactory.java

示例7: init

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
public void init(InetSocketAddress addr, ChannelPipelineFactory pipeFactory, ClientSocketChannelFactory factory)
    throws IOException {
  try {
    this.bootstrap = new ClientBootstrap(factory);
    this.bootstrap.setPipelineFactory(pipeFactory);
    // TODO - should be configurable
    this.bootstrap.setOption("connectTimeoutMillis", 10000);
    this.bootstrap.setOption("connectResponseTimeoutMillis", 10000);
    this.bootstrap.setOption("receiveBufferSize", 1048576 * 10);
    this.bootstrap.setOption("tcpNoDelay", true);
    this.bootstrap.setOption("keepAlive", true);

    connect(addr);
  } catch (Throwable t) {
    close();
    throw new IOException(t.getCause());
  }
}
 
开发者ID:apache,项目名称:incubator-tajo,代码行数:19,代码来源:NettyClientBase.java

示例8: init

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
public void init(InetSocketAddress addr, ChannelPipelineFactory pipeFactory, ClientSocketChannelFactory factory)
    throws IOException {
  try {

    this.bootstrap = new ClientBootstrap(factory);
    this.bootstrap.setPipelineFactory(pipeFactory);
    // TODO - should be configurable
    this.bootstrap.setOption("connectTimeoutMillis", 10000);
    this.bootstrap.setOption("connectResponseTimeoutMillis", 10000);
    this.bootstrap.setOption("receiveBufferSize", 1048576 * 10);
    this.bootstrap.setOption("tcpNoDelay", true);
    this.bootstrap.setOption("keepAlive", true);

    connect(addr);
  } catch (Throwable t) {
    close();
    throw new IOException("Connect error to " + addr + " cause " + t.getMessage(), t.getCause());
  }
}
 
开发者ID:gruter,项目名称:tajo-cdh,代码行数:20,代码来源:NettyClientBase.java

示例9: HttpClientFactory

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
/**
 * Creates a new HttpClientFactory.
 *
 * @param filters the filter chain shared by all Clients created by this factory
 * @param channelFactory the ClientSocketChannelFactory that all Clients created by this
 *          factory will share
 * @param shutdownFactory if true, the channelFactory will be shut down when this
 *          factory is shut down
 * @param executor an executor shared by all Clients created by this factory to schedule
 *          tasks
 * @param shutdownExecutor if true, the executor will be shut down when this factory is
 *          shut down
 * @param callbackExecutor an optional executor to invoke user callbacks that otherwise
 *          will be invoked by scheduler executor.
 * @param shutdownCallbackExecutor if true, the callback executor will be shut down when
 *          this factory is shut down
 */
public HttpClientFactory(FilterChain filters,
                         ClientSocketChannelFactory channelFactory,
                         boolean shutdownFactory,
                         ScheduledExecutorService executor,
                         boolean shutdownExecutor,
                         ExecutorService callbackExecutor,
                         boolean shutdownCallbackExecutor)
{
  this(filters,
       channelFactory,
       shutdownFactory,
       executor,
       shutdownExecutor,
       callbackExecutor,
       shutdownCallbackExecutor,
       NULL_JMX_MANAGER);
}
 
开发者ID:ppdai,项目名称:rest4j,代码行数:35,代码来源:HttpClientFactory.java

示例10: HttpNettyClient

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
/**
 * Creates a new HttpNettyClient with some default parameters
 *
 * @see #HttpNettyClient(ClientSocketChannelFactory,ScheduledExecutorService,int,int,int,int,int,SSLContext,SSLParameters,int,ExecutorService,int)
 */
public HttpNettyClient(ClientSocketChannelFactory factory,
                       ScheduledExecutorService executor,
                       int poolSize,
                       int requestTimeout,
                       int idleTimeout,
                       int shutdownTimeout,
                       int maxResponseSize)
{
  this(factory,
       executor,
       poolSize,
       requestTimeout,
       idleTimeout,
       shutdownTimeout,
       maxResponseSize,
       null,
       null,
       Integer.MAX_VALUE,
       executor,
       Integer.MAX_VALUE);
}
 
开发者ID:ppdai,项目名称:rest4j,代码行数:27,代码来源:HttpNettyClient.java

示例11: testShutdownTimeoutDoesNotOccupyExecutors

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
/**
 * Tests that even when the factory is shutdown with a long timeout, it does not occupy
 * any executors with tasks that might prevent them shutting down properly.
 * @throws InterruptedException
 * @throws ExecutionException
 * @throws TimeoutException
 */
@Test
public void testShutdownTimeoutDoesNotOccupyExecutors()
        throws InterruptedException, ExecutionException, TimeoutException
{
  ExecutorService boss = Executors.newCachedThreadPool();
  ExecutorService worker = Executors.newCachedThreadPool();
  ScheduledExecutorService scheduler = Executors.newSingleThreadScheduledExecutor();
  ClientSocketChannelFactory channelFactory = new NioClientSocketChannelFactory(boss, worker);
  HttpClientFactory factory = new HttpClientFactory(FilterChains.empty(), channelFactory, false, scheduler, false);

  FutureCallback<None> callback = new FutureCallback<None>();
  factory.shutdown(callback, 60, TimeUnit.MINUTES);
  callback.get(60, TimeUnit.SECONDS);
  scheduler.shutdown();
  channelFactory.releaseExternalResources();
  Assert.assertTrue(scheduler.awaitTermination(60, TimeUnit.SECONDS));
  Assert.assertTrue(boss.awaitTermination(60, TimeUnit.SECONDS));
  Assert.assertTrue(worker.awaitTermination(60, TimeUnit.SECONDS));
}
 
开发者ID:ppdai,项目名称:rest4j,代码行数:27,代码来源:TestHttpClientFactory.java

示例12: main

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
public static void main(String[] args) throws Exception {        

        Executor executor = Executors.newCachedThreadPool();
        ChannelFactory factory = new NioServerSocketChannelFactory(executor, executor);
        ServerBootstrap sb = new ServerBootstrap(factory);
        ClientSocketChannelFactory cf = new NioClientSocketChannelFactory(executor, executor);
        sb.setPipelineFactory(new ProxyPipelineFactory(cf,
                RtmpConfig.PROXY_REMOTE_HOST, RtmpConfig.PROXY_REMOTE_PORT));
        InetSocketAddress socketAddress = new InetSocketAddress(RtmpConfig.PROXY_PORT);
        sb.bind(socketAddress);
        logger.info("proxy server started, listening on {}", socketAddress);

        Thread monitor = new StopMonitor(RtmpConfig.PROXY_STOP_PORT);
        monitor.start();
        monitor.join();

        ChannelGroupFuture future = ALL_CHANNELS.close();
        logger.info("closing channels");
        future.awaitUninterruptibly();
        logger.info("releasing resources");
        factory.releaseExternalResources();
        logger.info("server stopped");

    }
 
开发者ID:bruni68510,项目名称:flazr,代码行数:25,代码来源:RtmpProxy.java

示例13: RedisClient

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
/**
 * Create a new client that connects to the supplied host and port. Connection
 * attempts and non-blocking commands will {@link #setDefaultTimeout timeout}
 * after 60 seconds.
 *
 * @param host    Server hostname.
 * @param port    Server port.
 */
public RedisClient(String host, int port) {
    ExecutorService connectors = Executors.newFixedThreadPool(1);
    ExecutorService workers    = Executors.newCachedThreadPool();
    ClientSocketChannelFactory factory = new NioClientSocketChannelFactory(connectors, workers);

    InetSocketAddress addr = new InetSocketAddress(host, port);

    bootstrap = new ClientBootstrap(factory);
    bootstrap.setOption("remoteAddress", addr);

    setDefaultTimeout(60, TimeUnit.SECONDS);

    channels = new DefaultChannelGroup();
    timer    = new HashedWheelTimer();
}
 
开发者ID:hakusaro,项目名称:ShankShock-Core,代码行数:24,代码来源:RedisClient.java

示例14: main

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
public static void main(String[] args) throws Exception {
    // Validate command line options.
    if (args.length != 3) {
        System.err.println("Usage: " + HexDumpProxy.class.getSimpleName() + " <local port> <remote host> <remote port>");
        return;
    }
    // Parse command line options.
    int localPort = Integer.parseInt(args[0]);
    String remoteHost = args[1];
    int remotePort = Integer.parseInt(args[2]);
    System.err.println("Proxying *:" + localPort + " to " + remoteHost + ':' + remotePort + " ...");
    // Configure the bootstrap.
    Executor executor = Executors.newCachedThreadPool();
    ServerBootstrap sb = new ServerBootstrap(new NioServerSocketChannelFactory(executor, executor));
    // Set up the event pipeline factory.
    ClientSocketChannelFactory cf = new NioClientSocketChannelFactory(executor, executor);
    sb.setPipelineFactory(new HexDumpProxyPipelineFactory(cf, remoteHost, remotePort));
    // Start up the server.
    sb.bind(new InetSocketAddress(localPort));
}
 
开发者ID:uli-heller,项目名称:uli-mini-tools,代码行数:21,代码来源:HexDumpProxy.java

示例15: main

import org.jboss.netty.channel.socket.ClientSocketChannelFactory; //导入依赖的package包/类
public static void main(String[] args) throws Exception {
    // Validate command line options.
    if (args.length != 3) {
        System.err.println(
                "Usage: " + TextDumpProxy.class.getSimpleName() +
                " <local port> <remote host> <remote port>");
        return;
    }
    // Parse command line options.
    int localPort = Integer.parseInt(args[0]);
    String remoteHost = args[1];
    int remotePort = Integer.parseInt(args[2]);

    System.err.println(
            "Proxying *:" + localPort + " to " +
            remoteHost + ':' + remotePort + " ...");
    // Configure the bootstrap.
    Executor executor = Executors.newCachedThreadPool();
    ServerBootstrap sb = new ServerBootstrap(new NioServerSocketChannelFactory(executor, executor));
    // Set up the event pipeline factory.
    ClientSocketChannelFactory cf = new NioClientSocketChannelFactory(executor, executor);
    sb.setPipelineFactory(new TextDumpProxyPipelineFactory(cf, remoteHost, remotePort));
    // Start up the server.
    sb.bind(new InetSocketAddress(localPort));
}
 
开发者ID:uli-heller,项目名称:uli-mini-tools,代码行数:26,代码来源:TextDumpProxy.java


注:本文中的org.jboss.netty.channel.socket.ClientSocketChannelFactory类示例由纯净天空整理自Github/MSDocs等开源代码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。