org.jboss.netty.channel.socket.ClientSocketChannelFactory Java Examples
The following examples show how to use
org.jboss.netty.channel.socket.ClientSocketChannelFactory.
You can vote up the ones you like or vote down the ones you don't like,
and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: NettyClientBase.java From incubator-tajo with Apache License 2.0 | 6 votes |
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()); } }
Example #2
Source File: RpcChannelFactory.java From incubator-tajo with Apache License 2.0 | 6 votes |
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); }
Example #3
Source File: AsyncRpcClient.java From incubator-tajo with Apache License 2.0 | 6 votes |
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); }
Example #4
Source File: BookKeeperClient.java From distributedlog with Apache License 2.0 | 6 votes |
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; } }
Example #5
Source File: BlockingRpcClient.java From incubator-tajo with Apache License 2.0 | 6 votes |
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); }
Example #6
Source File: Fetcher.java From incubator-tajo with Apache License 2.0 | 6 votes |
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); }
Example #7
Source File: NetworkFailuresProxy.java From Flink-CEPplus with Apache License 2.0 | 5 votes |
public NetworkFailuresProxy(int localPort, String remoteHost, int remotePort) { // Configure the bootstrap. serverBootstrap = new ServerBootstrap( new NioServerSocketChannelFactory(executor, executor)); // Set up the event pipeline factory. ClientSocketChannelFactory channelFactory = new NioClientSocketChannelFactory(executor, executor); serverBootstrap.setOption("child.tcpNoDelay", true); serverBootstrap.setOption("child.keepAlive", true); serverBootstrap.setPipelineFactory(new ChannelPipelineFactory() { public ChannelPipeline getPipeline() throws Exception { ChannelPipeline pipeline = Channels.pipeline(); // synchronized for a race between blocking and creating new handlers synchronized (networkFailureHandlers) { NetworkFailureHandler failureHandler = new NetworkFailureHandler( blocked, networkFailureHandler -> networkFailureHandlers.remove(networkFailureHandler), channelFactory, remoteHost, remotePort); networkFailureHandlers.add(failureHandler); pipeline.addLast(NETWORK_FAILURE_HANDLER_NAME, failureHandler); } return pipeline; } }); channel = serverBootstrap.bind(new InetSocketAddress(localPort)); LOG.info("Proxying [*:{}] to [{}:{}]", getLocalPort(), remoteHost, remotePort); }
Example #8
Source File: RpcChannelFactory.java From incubator-tajo with Apache License 2.0 | 5 votes |
/** * make this factory static thus all clients can share its thread pool. * NioClientSocketChannelFactory has only one method newChannel() visible for user, which is thread-safe */ public static synchronized ClientSocketChannelFactory getSharedClientChannelFactory(){ //shared woker and boss pool if(factory == null){ TajoConf conf = new TajoConf(); int workerNum = conf.getIntVar(TajoConf.ConfVars.INTERNAL_RPC_CLIENT_WORKER_THREAD_NUM); factory = createClientChannelFactory("Internal-Client", workerNum); } return factory; }
Example #9
Source File: TestFetcher.java From incubator-tajo with Apache License 2.0 | 5 votes |
@Test public void testGet() throws IOException { Random rnd = new Random(); FileWriter writer = new FileWriter(INPUT_DIR + "data"); String data; for (int i = 0; i < 100; i++) { data = ""+rnd.nextInt(); writer.write(data); } writer.flush(); writer.close(); DataRetriever ret = new DirectoryRetriever(INPUT_DIR); HttpDataServer server = new HttpDataServer( NetUtils.createSocketAddr("127.0.0.1:0"), ret); server.start(); InetSocketAddress addr = server.getBindAddress(); URI uri = URI.create("http://127.0.0.1:"+addr.getPort() + "/data"); ClientSocketChannelFactory channelFactory = RpcChannelFactory.createClientChannelFactory("Fetcher", 1); Fetcher fetcher = new Fetcher(uri, new File(OUTPUT_DIR + "data"), channelFactory); fetcher.get(); server.stop(); FileSystem fs = FileSystem.getLocal(new TajoConf()); FileStatus inStatus = fs.getFileStatus(new Path(INPUT_DIR, "data")); FileStatus outStatus = fs.getFileStatus(new Path(OUTPUT_DIR, "data")); assertEquals(inStatus.getLen(), outStatus.getLen()); }
Example #10
Source File: NetworkFailuresProxy.java From flink with Apache License 2.0 | 5 votes |
public NetworkFailuresProxy(int localPort, String remoteHost, int remotePort) { // Configure the bootstrap. serverBootstrap = new ServerBootstrap( new NioServerSocketChannelFactory(executor, executor)); // Set up the event pipeline factory. ClientSocketChannelFactory channelFactory = new NioClientSocketChannelFactory(executor, executor); serverBootstrap.setOption("child.tcpNoDelay", true); serverBootstrap.setOption("child.keepAlive", true); serverBootstrap.setPipelineFactory(new ChannelPipelineFactory() { public ChannelPipeline getPipeline() throws Exception { ChannelPipeline pipeline = Channels.pipeline(); // synchronized for a race between blocking and creating new handlers synchronized (networkFailureHandlers) { NetworkFailureHandler failureHandler = new NetworkFailureHandler( blocked, networkFailureHandler -> networkFailureHandlers.remove(networkFailureHandler), channelFactory, remoteHost, remotePort); networkFailureHandlers.add(failureHandler); pipeline.addLast(NETWORK_FAILURE_HANDLER_NAME, failureHandler); } return pipeline; } }); channel = serverBootstrap.bind(new InetSocketAddress(localPort)); LOG.info("Proxying [*:{}] to [{}:{}]", getLocalPort(), remoteHost, remotePort); }
Example #11
Source File: NetworkFailureHandler.java From flink with Apache License 2.0 | 5 votes |
public NetworkFailureHandler( AtomicBoolean blocked, Consumer<NetworkFailureHandler> onClose, ClientSocketChannelFactory channelFactory, String remoteHost, int remotePort) { this.blocked = blocked; this.onClose = onClose; this.channelFactory = channelFactory; this.remoteHost = remoteHost; this.remotePort = remotePort; }
Example #12
Source File: NetworkFailuresProxy.java From flink with Apache License 2.0 | 5 votes |
public NetworkFailuresProxy(int localPort, String remoteHost, int remotePort) { // Configure the bootstrap. serverBootstrap = new ServerBootstrap( new NioServerSocketChannelFactory(executor, executor)); // Set up the event pipeline factory. ClientSocketChannelFactory channelFactory = new NioClientSocketChannelFactory(executor, executor); serverBootstrap.setOption("child.tcpNoDelay", true); serverBootstrap.setOption("child.keepAlive", true); serverBootstrap.setPipelineFactory(new ChannelPipelineFactory() { public ChannelPipeline getPipeline() throws Exception { ChannelPipeline pipeline = Channels.pipeline(); // synchronized for a race between blocking and creating new handlers synchronized (networkFailureHandlers) { NetworkFailureHandler failureHandler = new NetworkFailureHandler( blocked, networkFailureHandler -> networkFailureHandlers.remove(networkFailureHandler), channelFactory, remoteHost, remotePort); networkFailureHandlers.add(failureHandler); pipeline.addLast(NETWORK_FAILURE_HANDLER_NAME, failureHandler); } return pipeline; } }); channel = serverBootstrap.bind(new InetSocketAddress(localPort)); LOG.info("Proxying [*:{}] to [{}:{}]", getLocalPort(), remoteHost, remotePort); }
Example #13
Source File: NetworkFailureHandler.java From flink with Apache License 2.0 | 5 votes |
public NetworkFailureHandler( AtomicBoolean blocked, Consumer<NetworkFailureHandler> onClose, ClientSocketChannelFactory channelFactory, String remoteHost, int remotePort) { this.blocked = blocked; this.onClose = onClose; this.channelFactory = channelFactory; this.remoteHost = remoteHost; this.remotePort = remotePort; }
Example #14
Source File: NetworkFailureHandler.java From Flink-CEPplus with Apache License 2.0 | 5 votes |
public NetworkFailureHandler( AtomicBoolean blocked, Consumer<NetworkFailureHandler> onClose, ClientSocketChannelFactory channelFactory, String remoteHost, int remotePort) { this.blocked = blocked; this.onClose = onClose; this.channelFactory = channelFactory; this.remoteHost = remoteHost; this.remotePort = remotePort; }
Example #15
Source File: BookKeeperClient.java From distributedlog with Apache License 2.0 | 4 votes |
@SuppressWarnings("deprecation") private synchronized void commonInitialization( DistributedLogConfiguration conf, String ledgersPath, ClientSocketChannelFactory channelFactory, StatsLogger statsLogger, HashedWheelTimer requestTimer, boolean registerExpirationHandler) throws IOException, InterruptedException, KeeperException { ClientConfiguration bkConfig = new ClientConfiguration(); bkConfig.setAddEntryTimeout(conf.getBKClientWriteTimeout()); bkConfig.setReadTimeout(conf.getBKClientReadTimeout()); bkConfig.setZkLedgersRootPath(ledgersPath); bkConfig.setZkTimeout(conf.getBKClientZKSessionTimeoutMilliSeconds()); bkConfig.setNumWorkerThreads(conf.getBKClientNumberWorkerThreads()); bkConfig.setEnsemblePlacementPolicy(RegionAwareEnsemblePlacementPolicy.class); bkConfig.setZkRequestRateLimit(conf.getBKClientZKRequestRateLimit()); bkConfig.setProperty(RegionAwareEnsemblePlacementPolicy.REPP_DISALLOW_BOOKIE_PLACEMENT_IN_REGION_FEATURE_NAME, DistributedLogConstants.DISALLOW_PLACEMENT_IN_REGION_FEATURE_NAME); // reload configuration from dl configuration with settings prefixed with 'bkc.' ConfUtils.loadConfiguration(bkConfig, conf, "bkc."); Class<? extends DNSToSwitchMapping> dnsResolverCls; try { dnsResolverCls = conf.getEnsemblePlacementDnsResolverClass(); } catch (ConfigurationException e) { LOG.error("Failed to load bk dns resolver : ", e); throw new IOException("Failed to load bk dns resolver : ", e); } final DNSToSwitchMapping dnsResolver = NetUtils.getDNSResolver(dnsResolverCls, conf.getBkDNSResolverOverrides()); this.bkc = BookKeeper.newBuilder() .config(bkConfig) .zk(zkc.get()) .channelFactory(channelFactory) .statsLogger(statsLogger) .dnsResolver(dnsResolver) .requestTimer(requestTimer) .featureProvider(featureProvider.orNull()) .build(); if (registerExpirationHandler) { sessionExpireWatcher = this.zkc.registerExpirationHandler(this); } }
Example #16
Source File: RpcConnectionPool.java From incubator-tajo with Apache License 2.0 | 4 votes |
private RpcConnectionPool(TajoConf conf, ClientSocketChannelFactory channelFactory) { this.conf = conf; this.channelFactory = channelFactory; }
Example #17
Source File: MongoProxyServer.java From usergrid with Apache License 2.0 | 4 votes |
public static void main( String[] args ) throws Exception { logger.info( "Starting Usergrid Mongo Proxy Server" ); // Configure the server. Executor executor = Executors.newCachedThreadPool(); ServerBootstrap bootstrap = new ServerBootstrap( new NioServerSocketChannelFactory( executor, executor ) ); bootstrap.setOption( "child.bufferFactory", HeapChannelBufferFactory.getInstance( ByteOrder.LITTLE_ENDIAN ) ); ClientSocketChannelFactory cf = new NioClientSocketChannelFactory( executor, executor ); bootstrap.setPipelineFactory( new MongoProxyPipelineFactory( cf, "localhost", 12345 ) ); bootstrap.bind( new InetSocketAddress( 27017 ) ); logger.info( "Usergrid Mongo Proxy Server accepting connections..." ); }
Example #18
Source File: MongoProxyPipelineFactory.java From usergrid with Apache License 2.0 | 4 votes |
public MongoProxyPipelineFactory( ClientSocketChannelFactory cf, String remoteHost, int remotePort ) { this.cf = cf; this.remoteHost = remoteHost; this.remotePort = remotePort; }
Example #19
Source File: MongoProxyInboundHandler.java From usergrid with Apache License 2.0 | 4 votes |
public MongoProxyInboundHandler( ClientSocketChannelFactory cf, String remoteHost, int remotePort ) { this.cf = cf; this.remoteHost = remoteHost; this.remotePort = remotePort; }