java.net.SocketAddress Java Examples
The following examples show how to use
java.net.SocketAddress.
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: AsynchronousSocketChannelImpl.java From dragonwell8_jdk with GNU General Public License v2.0 | 6 votes |
@Override public final AsynchronousSocketChannel bind(SocketAddress local) throws IOException { try { begin(); synchronized (stateLock) { if (state == ST_PENDING) throw new ConnectionPendingException(); if (localAddress != null) throw new AlreadyBoundException(); InetSocketAddress isa = (local == null) ? new InetSocketAddress(0) : Net.checkAddress(local); SecurityManager sm = System.getSecurityManager(); if (sm != null) { sm.checkListen(isa.getPort()); } NetHooks.beforeTcpBind(fd, isa.getAddress(), isa.getPort()); Net.bind(fd, isa.getAddress(), isa.getPort()); localAddress = Net.localAddress(fd); } } finally { end(); } return this; }
Example #2
Source File: SocketChannelTest.java From kieker with Apache License 2.0 | 6 votes |
@Test public void socketChannelShouldAlwaysReturnTheSameSocket() throws Exception { final SocketAddress socketAddress = new InetSocketAddress(this.hostname, this.port); final int timeout = 1; final SocketChannel socketChannel = SocketChannel.open(); final Socket socket = socketChannel.socket(); try { socket.connect(socketAddress, timeout); } catch (SocketTimeoutException | ConnectException e) { // NOPMD (empty catch block) // both of the exceptions indicate a connection timeout // => ignore to reconnect } // The previous connect should throw an exception assertThat(socket.isConnected(), is(false)); // NOPMD (JUnit message is not necessary) }
Example #3
Source File: SctpChannelImpl.java From openjdk-8 with GNU General Public License v2.0 | 6 votes |
@Override public Set<SocketAddress> getRemoteAddresses() throws IOException { synchronized (stateLock) { if (!isOpen()) throw new ClosedChannelException(); if (!isConnected() || isShutdown) return Collections.emptySet(); try { return SctpNet.getRemoteAddresses(fdVal, 0/*unused*/); } catch (SocketException unused) { /* an open connected channel should always have remote addresses */ return remoteAddresses; } } }
Example #4
Source File: ChildLbResolvedAddressFactoryTest.java From grpc-java with Apache License 2.0 | 6 votes |
@Test public void create() { List<EquivalentAddressGroup> addrs = new ArrayList<>(); addrs.add(new EquivalentAddressGroup(mock(SocketAddress.class))); Attributes attr = Attributes.newBuilder().build(); ChildLbResolvedAddressFactory factory = new ChildLbResolvedAddressFactory(addrs, attr); Object config1 = new Object(); ResolvedAddresses resolvedAddress = factory.create(config1); assertThat(resolvedAddress.getAddresses()).isEqualTo(addrs); assertThat(resolvedAddress.getAttributes()).isEqualTo(attr); assertThat(resolvedAddress.getLoadBalancingPolicyConfig()).isEqualTo(config1); Object config2 = "different object"; resolvedAddress = factory.create(config2); assertThat(resolvedAddress.getAddresses()).isEqualTo(addrs); assertThat(resolvedAddress.getAttributes()).isEqualTo(attr); assertThat(resolvedAddress.getLoadBalancingPolicyConfig()).isEqualTo(config2); }
Example #5
Source File: AsynchronousServerSocketChannelImpl.java From jdk8u_jdk with GNU General Public License v2.0 | 6 votes |
@Override public final AsynchronousServerSocketChannel bind(SocketAddress local, int backlog) throws IOException { InetSocketAddress isa = (local == null) ? new InetSocketAddress(0) : Net.checkAddress(local); SecurityManager sm = System.getSecurityManager(); if (sm != null) sm.checkListen(isa.getPort()); try { begin(); synchronized (stateLock) { if (localAddress != null) throw new AlreadyBoundException(); NetHooks.beforeTcpBind(fd, isa.getAddress(), isa.getPort()); Net.bind(fd, isa.getAddress(), isa.getPort()); Net.listen(fd, backlog < 1 ? 50 : backlog); localAddress = Net.localAddress(fd); } } finally { end(); } return this; }
Example #6
Source File: ReceiveIntoDirect.java From openjdk-jdk8u-backup with GNU General Public License v2.0 | 6 votes |
void runWithManyOffsets(SocketAddress addr, int bufferSize) throws IOException { doTest(addr, bufferSize, 1); doTest(addr, bufferSize, 2); doTest(addr, bufferSize, 3); doTest(addr, bufferSize, 4); doTest(addr, bufferSize, 5); doTest(addr, bufferSize, 6); doTest(addr, bufferSize, 7); doTest(addr, bufferSize, 8); doTest(addr, bufferSize, 9); doTest(addr, bufferSize, 10); doTest(addr, bufferSize, 11); doTest(addr, bufferSize, 12); doTest(addr, bufferSize, 13); doTest(addr, bufferSize, 14); doTest(addr, bufferSize, 15); }
Example #7
Source File: ConnectionUtils.java From flink with Apache License 2.0 | 6 votes |
/** * This utility method tries to connect to the JobManager using the InetAddress returned by * InetAddress.getLocalHost(). The purpose of the utility is to have a final try connecting to * the target address using the LocalHost before using the address returned. * We do a second try because the JM might have been unavailable during the first check. * * @param preliminaryResult The address detected by the heuristic * @return either the preliminaryResult or the address returned by InetAddress.getLocalHost() (if * we are able to connect to targetAddress from there) */ private static InetAddress tryLocalHostBeforeReturning( InetAddress preliminaryResult, SocketAddress targetAddress, boolean logging) throws IOException { InetAddress localhostName = InetAddress.getLocalHost(); if (preliminaryResult.equals(localhostName)) { // preliminary result is equal to the local host name return preliminaryResult; } else if (tryToConnect(localhostName, targetAddress, AddressDetectionState.SLOW_CONNECT.getTimeout(), logging)) { // success, we were able to use local host to connect LOG.debug("Preferring {} (InetAddress.getLocalHost()) for local bind point over previous candidate {}", localhostName, preliminaryResult); return localhostName; } else { // we have to make the preliminary result the final result return preliminaryResult; } }
Example #8
Source File: Bootstrap.java From netty-4.1.22 with Apache License 2.0 | 6 votes |
private static void doConnect( final SocketAddress remoteAddress, final SocketAddress localAddress, final ChannelPromise connectPromise) { // This method is invoked before channelRegistered() is triggered. Give user handlers a chance to set up // the pipeline in its channelRegistered() implementation.//这个方法在触发channelRegistered()之前被调用。给用户处理程序一个设置的机会 //管道的channelRegistered()实现。 final Channel channel = connectPromise.channel(); channel.eventLoop().execute(new Runnable() { @Override public void run() { if (localAddress == null) { // 远程连接 channel.connect(remoteAddress, connectPromise); } else { // 本地连接 channel.connect(remoteAddress, localAddress, connectPromise); } connectPromise.addListener(ChannelFutureListener.CLOSE_ON_FAILURE); } }); }
Example #9
Source File: Receive.java From openjdk-jdk8u-backup with GNU General Public License v2.0 | 5 votes |
public Server() throws IOException { ssc = SctpServerChannel.open().bind(null); java.util.Set<SocketAddress> addrs = ssc.getAllLocalAddresses(); if (addrs.isEmpty()) debug("addrs should not be empty"); serverAddr = (InetSocketAddress) addrs.iterator().next(); }
Example #10
Source File: Util.java From openjdk-jdk8u-backup with GNU General Public License v2.0 | 5 votes |
static void dumpAddresses(SctpChannel channel, PrintStream printStream) throws IOException { Set<SocketAddress> addrs = channel.getAllLocalAddresses(); printStream.println("Local Addresses: "); for (Iterator<SocketAddress> it = addrs.iterator(); it.hasNext(); ) { InetSocketAddress addr = (InetSocketAddress)it.next(); printStream.println("\t" + addr); } }
Example #11
Source File: DatagramSocketAdaptor.java From Bytecoder with Apache License 2.0 | 5 votes |
private void connectInternal(SocketAddress remote) throws SocketException { try { dc.connect(remote, false); // skips check for already connected } catch (ClosedChannelException e) { // ignore } catch (Exception x) { Net.translateToSocketException(x); } }
Example #12
Source File: RemotingHelper.java From RocketMQ-Master-analyze with Apache License 2.0 | 5 votes |
public static String parseSocketAddressName(SocketAddress socketAddress) { final InetSocketAddress addrs = (InetSocketAddress) socketAddress; if (addrs != null) { return addrs.getAddress().getHostName(); } return ""; }
Example #13
Source File: Client.java From r2dbc-mysql with Apache License 2.0 | 5 votes |
static Mono<Client> connect(SocketAddress address, MySqlSslConfiguration ssl, ConnectionContext context, @Nullable Duration connectTimeout) { requireNonNull(address, "address must not be null"); requireNonNull(ssl, "ssl must not be null"); requireNonNull(context, "context must not be null"); TcpClient tcpClient = TcpClient.newConnection(); if (connectTimeout != null) { tcpClient = tcpClient.option(ChannelOption.CONNECT_TIMEOUT_MILLIS, Math.toIntExact(connectTimeout.toMillis())); } return tcpClient.remoteAddress(() -> address).connect() .map(conn -> new ReactorNettyClient(conn, ssl, context)); }
Example #14
Source File: DFSClient.java From big-c with Apache License 2.0 | 5 votes |
/** * Select one of the configured local interfaces at random. We use a random * interface because other policies like round-robin are less effective * given that we cache connections to datanodes. * * @return one of the local interface addresses at random, or null if no * local interfaces are configured */ SocketAddress getRandomLocalInterfaceAddr() { if (localInterfaceAddrs.length == 0) { return null; } final int idx = r.nextInt(localInterfaceAddrs.length); final SocketAddress addr = localInterfaceAddrs[idx]; if (LOG.isDebugEnabled()) { LOG.debug("Using local interface " + addr); } return addr; }
Example #15
Source File: PeerManager.java From tchannel-java with MIT License | 5 votes |
public Peer findOrNewPeer(@NotNull SocketAddress address) { Peer peer = peers.get(address); if (peer == null) { peers.putIfAbsent(address, new Peer(this, address)); peer = peers.get(address); } return peer; }
Example #16
Source File: MicrometerHttpServerMetricsRecorder.java From reactor-netty with Apache License 2.0 | 5 votes |
@Override public void recordDataReceived(SocketAddress remoteAddress, String uri, long bytes) { DistributionSummary dataReceived = dataReceivedCache.computeIfAbsent(new MeterKey(uri, null, null, null), key -> filter(dataReceivedBuilder.tags(URI, uri) .register(REGISTRY))); if (dataReceived != null) { dataReceived.record(bytes); } }
Example #17
Source File: LoggingHandler.java From netty4.0.27Learn with Apache License 2.0 | 5 votes |
@Override public void connect(ChannelHandlerContext ctx, SocketAddress remoteAddress, SocketAddress localAddress, ChannelPromise promise) throws Exception { if (logger.isEnabled(internalLevel)) { logger.log(internalLevel, format(ctx, "CONNECT(" + remoteAddress + ", " + localAddress + ')')); } super.connect(ctx, remoteAddress, localAddress, promise); }
Example #18
Source File: BlockingClientManager.java From green_android with GNU General Public License v3.0 | 5 votes |
@Override public ListenableFuture<SocketAddress> openConnection(SocketAddress serverAddress, StreamConnection connection) { try { if (!isRunning()) throw new IllegalStateException(); return new BlockingClient(serverAddress, connection, connectTimeoutMillis, socketFactory, clients).getConnectFuture(); } catch (IOException e) { throw new RuntimeException(e); // This should only happen if we are, eg, out of system resources } }
Example #19
Source File: RpcProgram.java From big-c with Apache License 2.0 | 5 votes |
protected static void sendRejectedReply(RpcCall call, SocketAddress remoteAddress, ChannelHandlerContext ctx) { XDR out = new XDR(); RpcDeniedReply reply = new RpcDeniedReply(call.getXid(), RpcReply.ReplyState.MSG_DENIED, RpcDeniedReply.RejectState.AUTH_ERROR, new VerifierNone()); reply.write(out); ChannelBuffer buf = ChannelBuffers.wrappedBuffer(out.asReadOnlyWrap() .buffer()); RpcResponse rsp = new RpcResponse(buf, remoteAddress); RpcUtil.sendRpcResponse(ctx, rsp); }
Example #20
Source File: Helper.java From packagedrone with Eclipse Public License 1.0 | 5 votes |
private static Proxy getProxy ( final String url ) { final ProxySelector ps = ProxySelector.getDefault (); if ( ps == null ) { logger.debug ( "No proxy selector found" ); return null; } final List<java.net.Proxy> proxies = ps.select ( URI.create ( url ) ); for ( final java.net.Proxy proxy : proxies ) { if ( proxy.type () != Type.HTTP ) { logger.debug ( "Unsupported proxy type: {}", proxy.type () ); continue; } final SocketAddress addr = proxy.address (); logger.debug ( "Proxy address: {}", addr ); if ( ! ( addr instanceof InetSocketAddress ) ) { logger.debug ( "Unsupported proxy address type: {}", addr.getClass () ); continue; } final InetSocketAddress inetAddr = (InetSocketAddress)addr; return new Proxy ( Proxy.TYPE_HTTP, inetAddr.getHostString (), inetAddr.getPort () ); } logger.debug ( "No proxy found" ); return null; }
Example #21
Source File: RemotingUtil.java From rocketmq with Apache License 2.0 | 5 votes |
public static String socketAddress2String(final SocketAddress addr) { StringBuilder sb = new StringBuilder(); InetSocketAddress inetSocketAddress = (InetSocketAddress)addr; sb.append(inetSocketAddress.getAddress().getHostAddress()); sb.append(":"); sb.append(inetSocketAddress.getPort()); return sb.toString(); }
Example #22
Source File: ProtocolCompatibilityTest.java From servicetalk with Apache License 2.0 | 5 votes |
private static CompatClient serviceTalkClient(final SocketAddress serverAddress, final boolean ssl) { final GrpcClientBuilder<InetSocketAddress, InetSocketAddress> builder = GrpcClients.forResolvedAddress((InetSocketAddress) serverAddress); if (ssl) { builder.secure().disableHostnameVerification().provider(OPENSSL) .trustManager(DefaultTestCerts::loadServerPem).commit(); } return builder.build(new Compat.ClientFactory()); }
Example #23
Source File: AbstractXnioSocketChannel.java From netty-xnio-transport with Apache License 2.0 | 5 votes |
@Override protected SocketAddress localAddress0() { StreamConnection conn = connection(); if (conn == null) { return null; } return conn.getLocalAddress(); }
Example #24
Source File: Send.java From jdk8u60 with GNU General Public License v2.0 | 5 votes |
public Server() throws IOException { ssc = SctpServerChannel.open().bind(null); java.util.Set<SocketAddress> addrs = ssc.getAllLocalAddresses(); if (addrs.isEmpty()) debug("addrs should not be empty"); serverAddr = (InetSocketAddress) addrs.iterator().next(); }
Example #25
Source File: AbstractIoAcceptor.java From neoscada with Eclipse Public License 1.0 | 5 votes |
/** * {@inheritDoc} */ public final void bind(SocketAddress... addresses) throws IOException { if ((addresses == null) || (addresses.length == 0)) { bind(getDefaultLocalAddresses()); return; } List<SocketAddress> localAddresses = new ArrayList<SocketAddress>(2); for (SocketAddress address : addresses) { localAddresses.add(address); } bind(localAddresses); }
Example #26
Source File: RtmpConnection.java From rtspTortmp with Apache License 2.0 | 5 votes |
@Override public void connect() throws IOException { L.d("RtmpConnection.connect() called. Host: " + host + ", port: " + port + ", appName: " + appName + ", playPath: " + streamName); socket = new Socket(); SocketAddress socketAddress = new InetSocketAddress(host, port); socket.connect(socketAddress, SOCKET_CONNECT_TIMEOUT_MS); BufferedInputStream in = new BufferedInputStream(socket.getInputStream()); BufferedOutputStream out = new BufferedOutputStream(socket.getOutputStream()); L.d("RtmpConnection.connect(): socket connection established, doing handhake..."); handshake(in, out); active = true; L.d("RtmpConnection.connect(): handshake done"); readThread = new ReadThread(rtmpSessionInfo, in, this, this); writeThread = new WriteThread(rtmpSessionInfo, out, this); readThread.start(); writeThread.start(); // Start the "main" handling thread new Thread(new Runnable() { @Override public void run() { try { L.d("RtmpConnection: starting main rx handler loop"); handleRxPacketLoop(); } catch (IOException ex) { Logger.getLogger(RtmpConnection.class.getName()).log(Level.SEVERE, null, ex); } } }).start(); // rxHandler; rtmpConnect(); }
Example #27
Source File: TNonblockingSocket.java From incubator-retired-blur with Apache License 2.0 | 5 votes |
private TNonblockingSocket(SocketChannel socketChannel, int timeout, SocketAddress socketAddress) throws IOException { socketChannel_ = socketChannel; socketAddress_ = socketAddress; // make it a nonblocking channel socketChannel.configureBlocking(false); // set options Socket socket = socketChannel.socket(); socket.setSoLinger(false, 0); socket.setTcpNoDelay(true); setTimeout(timeout); }
Example #28
Source File: SyslogServerSessionTest.java From syslog4j with GNU Lesser General Public License v2.1 | 5 votes |
public void sessionClosed(Object session, SyslogServerIF syslogServer, SocketAddress socketAddress, boolean timeout) { if (session != null) { int i = translate((String) session); if (i != -1) { closeCount[i]++; } } System.out.println("closed: " + id + "/" + session.toString()); }
Example #29
Source File: SmtpConsumer.java From localization_nifi with Apache License 2.0 | 5 votes |
private Map<String, String> extractMessageAttributes() { final Map<String, String> attributes = new HashMap<>(); final Certificate[] tlsPeerCertificates = context.getTlsPeerCertificates(); if (tlsPeerCertificates != null) { for (int i = 0; i < tlsPeerCertificates.length; i++) { if (tlsPeerCertificates[i] instanceof X509Certificate) { X509Certificate x509Cert = (X509Certificate) tlsPeerCertificates[i]; attributes.put("smtp.certificate." + i + ".serial", x509Cert.getSerialNumber().toString()); attributes.put("smtp.certificate." + i + ".subjectName", x509Cert.getSubjectDN().getName()); } } } SocketAddress address = context.getRemoteAddress(); if (address != null) { // will extract and format source address if available String strAddress = address instanceof InetSocketAddress ? ((InetSocketAddress) address).getHostString() + ":" + ((InetSocketAddress) address).getPort() : context.getRemoteAddress().toString(); attributes.put("smtp.src", strAddress); } attributes.put("smtp.helo", context.getHelo()); attributes.put("smtp.from", from); for (int i = 0; i < recipientList.size(); i++) { attributes.put("smtp.recipient." + i, recipientList.get(i)); } attributes.put(CoreAttributes.MIME_TYPE.key(), "message/rfc822"); return attributes; }
Example #30
Source File: SctpChannelImpl.java From openjdk-jdk9 with GNU General Public License v2.0 | 5 votes |
@Override public boolean connect(SocketAddress endpoint, int maxOutStreams, int maxInStreams) throws IOException { ensureOpenAndUnconnected(); return setOption(SCTP_INIT_MAXSTREAMS, InitMaxStreams. create(maxInStreams, maxOutStreams)).connect(endpoint); }