微信公众号搜"智元新知"关注
微信扫一扫可直接关注哦!

java.net.ConnectException的实例源码

项目:AppServiceRestFul    文件HttpSubscriber.java   
@Override
public void onError(Throwable e) {
    if(subscriberOnListener != null && context != null)
    {
        if (e instanceof SocketTimeoutException) {
            subscriberOnListener.onError(-1001,"网络超时,请检查您的网络状态");
        } else if (e instanceof ConnectException) {
            subscriberOnListener.onError(-1002,"网络链接中断,请检查您的网络状态");
        } else if(e instanceof ExceptionApi){
            subscriberOnListener.onError(((ExceptionApi)e).getCode(),((ExceptionApi)e).getMsg());
        }
        else
        {
            subscriberOnListener.onError(-1003,"未知错误:" + e.getMessage());
        }
    }
    else
    {
        if(disposable != null && !disposable.isdisposed())
            disposable.dispose();
    }
}
项目:oscm    文件ProductProvisioningServicefactorybeanTest.java   
@Ignore
@Test(expected = ConnectException.class)
public void test_NoUser() throws Throwable {
    ServiceInstance instance = new ServiceInstance();
    ArrayList<InstanceParameter> params = new ArrayList<InstanceParameter>();
    params.add(PUBLIC_IP);
    params.add(WSDL);
    params.add(PROTOCOL);
    params.add(PORT);
    instance.setInstanceParameters(params);
    try {
        getInstance(instance);
    } catch (BadResultException e) {
        throw e.getCause();
    }
}
项目:GitHub    文件RealConnection.java   
/** Does all the work necessary to build a full HTTP or HTTPS connection on a raw socket. */
private void connectSocket(int connectTimeout,int readTimeout) throws IOException {
  Proxy proxy = route.proxy();
  Address address = route.address();

  rawSocket = proxy.type() == Proxy.Type.DIRECT || proxy.type() == Proxy.Type.HTTP
      ? address.socketFactory().createSocket()
      : new Socket(proxy);

  rawSocket.setSoTimeout(readTimeout);
  try {
    Platform.get().connectSocket(rawSocket,route.socketAddress(),connectTimeout);
  } catch (ConnectException e) {
    ConnectException ce = new ConnectException("Failed to connect to " + route.socketAddress());
    ce.initCause(e);
    throw ce;
  }
  source = Okio.buffer(Okio.source(rawSocket));
  sink = Okio.buffer(Okio.sink(rawSocket));
}
项目:GitHub    文件URLConnectionTest.java   
@Test public void getKeepAlive() throws Exception {
  server.enqueue(new MockResponse().setBody("ABC"));

  // The request should work once and then fail
  HttpURLConnection connection1 = urlFactory.open(server.url("/").url());
  connection1.setReadTimeout(100);
  InputStream input = connection1.getInputStream();
  assertEquals("ABC",readAscii(input,Integer.MAX_VALUE));
  server.shutdown();
  try {
    HttpURLConnection connection2 = urlFactory.open(server.url("").url());
    connection2.setReadTimeout(100);
    connection2.getInputStream();
    fail();
  } catch (ConnectException expected) {
  }
}
项目:hadoop    文件ExceptionDiags.java   
/**
 * Take an IOException and a URI,wrap it where possible with
 * something that includes the URI
 *
 * @param dest target URI
 * @param operation operation
 * @param exception the caught exception.
 * @return an exception to throw
 */
public static IOException wrapException(final String dest,final String operation,final IOException exception) {
  String action = operation + " " + dest;
  String xref = null;

  if (exception instanceof ConnectException) {
    xref = "ConnectionRefused";
  } else if (exception instanceof UnkNownHostException) {
    xref = "UnkNownHost";
  } else if (exception instanceof SocketTimeoutException) {
    xref = "SocketTimeout";
  } else if (exception instanceof noroutetoHostException) {
    xref = "noroutetoHost";
  }
  String msg = action
               + " Failed on exception: "
               + exception;
  if (xref != null) {
     msg = msg + ";" + see(xref);
  }
  return wrapWithMessage(exception,msg);
}
项目:netty-connection-pool    文件BasicMultiNodeConnPool.java   
@Override
public void preCreateConnections(final int count)
throws ConnectException,IllegalArgumentException {
    if(count > 0) {
        for(int i = 0; i < count; i ++) {
            final Channel conn = connectToAnyNode();
            if(conn == null) {
                throw new ConnectException(
                    "Failed to pre-create the connections to the target nodes"
                );
            }
            final String nodeAddr = conn.attr(ATTR_KEY_NODE).get();
            if(conn.isActive()) {
                final Queue<Channel> connQueue = availableConns.get(nodeAddr);
                if(connQueue != null) {
                    connQueue.add(conn);
                }
            } else {
                conn.close();
            }
        }
        LOG.info("Pre-created " + count + " connections");
    } else {
        throw new IllegalArgumentException("Connection count should be > 0,but got " + count);
    }
}
项目:uavstack    文件AppHubBaseRestService.java   
@Override
public void Failed(HttpClientCallbackResult result) {

    /**
     * auto fail record
     */
    HttpAsyncException e = result.getException();

    if (e != null && ((e.getCause() instanceof java.net.ConnectException)
            && e.getCause().getMessage().indexOf("Connection refused") > -1)) {

        getLogger().err(this,"Connection[" + postURL + "] is Unavailable. ",e);

        cfm.putFailConnection(url);
        /**
         * let's retry
         */
        doHttpPost(serverAddress,subPath,data,contentType,encoding,callBack);
        return;
    }

    if (callBack != null) {
        callBack.Failed(result);
    }
}
项目:AndroidSourceViewer    文件SearchDownload.java   
@Override
public Pair<Boolean,List<File>> onDownload(@NotNull ClassEntity[] classEntities,@NotNull File outputFolder) {
    String newUrl = null;
    try {
        newUrl = androidOnlinesearch(classEntities[0]);
    } catch (ConnectException | UnkNownHostException e1) {
        if (timeoutListener != null) {
            timeoutListener.run();
        }
    } catch (Exception e) {
        Log.e(e);
    }
    if (!Utils.isEmpty(newUrl)) {
        for (ClassEntity entity : classEntities) {
            entity.setDownloadUrl(newUrl);
        }
        Log.debug("SearchDownload => " + newUrl);
        return new XrefDownload().onDownload(classEntities,outputFolder);
    }
    return Pair.create(false,Collections.<File>emptyList());
}
项目:oscm    文件BssClient.java   
public String logoutUser(String saasId) throws servletexception,remoteexception {
    SessionServiceStub stub = new SessionServiceStub(getEndPoint(false));
    setBasicAuth(stub);
    SessionServiceStub.DeleteServiceSessionE dss = new SessionServiceStub.DeleteServiceSessionE();
    SessionServiceStub.DeleteServiceSession param = new SessionServiceStub.DeleteServiceSession();
    param.setSessionId(getSessionId(saasId));
    param.setSubscriptionKey(getSubscriptionKey(saasId));
    dss.setDeleteServiceSession(param);
    try {
        DeleteServiceSessionResponseE response = stub
                .deleteServiceSession(dss);
        return response.getDeleteServiceSessionResponse().get_return();
    } catch (AxisFault e) {
        if (port < 8185 && searchPort
                && e.getDetail() instanceof ConnectException) {
            // try again with another port
            port++;
            return logoutUser(saasId);
        }
        throw new servletexception(e);
    }
}
项目:hekate    文件NetworkClientTest.java   
@Test
public void testConnectToUnkNown() throws Exception {
    NetworkClient<String> client = createClient(f -> f.setConnectTimeout(Integer.MAX_VALUE));

    repeat(3,i -> {
        NetworkClientCallbackMock<String> callback = new NetworkClientCallbackMock<>();

        assertSame(NetworkClient.State.disCONNECTED,client.state());

        try {
            client.connect(new InetSocketAddress(InetAddress.getLocalHost(),15001),callback).get();

            fail("Error was expected");
        } catch (ExecutionException e) {
            assertTrue(e.getCause().toString(),ErrorUtils.isCausedBy(ConnectException.class,e));
        }

        assertSame(NetworkClient.State.disCONNECTED,client.state());
        assertNull(client.remoteAddress());
        assertNull(client.localAddress());
        callback.assertConnects(0);
        callback.assertdisconnects(1);
        callback.assertErrors(1);
        callback.getErrors().forEach(e -> assertTrue(e.toString(),e instanceof ConnectException));
    });
}
项目:incubator-netbeans    文件NativeExecutionTestSupport.java   
private static RcFile createRemoteRcFile(ExecutionEnvironment env)
        throws IOException,RcFile.FormatException,ConnectException,CancellationException,InterruptedException,ExecutionException {
    if (!ConnectionManager.getInstance().isConnectedTo(env)) {
        new Exception("WARNING: getRemoteRcFile changes connection state for " + env).printstacktrace();
        ConnectionManager.getInstance().connectTo(env);
    }
    String envText = ExecutionEnvironmentFactory.toUniqueID(env).replace(':','-').replace('@','-');
    String tmpName = "cnd_remote_test_rc_" + envText;
    File tmpFile = File.createTempFile(tmpName,"");
    tmpFile.deleteOnExit();
    String remoteFilePath = HostInfoUtils.getHostInfo(env).getUserDir() + "/.cnd-remote-test-rc";
    if (fileExists(env,remoteFilePath)) {
        int rc = CommonTasksSupport.downloadFile(remoteFilePath,env,tmpFile,new PrintWriter(System.err)).get();
        if (rc != 0) {
            throw new IOException("Can't download file " + remoteFilePath + " from " + env);
        }
        return RcFile.create(tmpFile);
    } else {
        return RcFile.createDummy();
    }
}
项目:incubator-netbeans    文件BugzillaExecutor.java   
private static String getNotFoundError(CoreException ce) {
    IStatus status = ce.getStatus();
    Throwable t = status.getException();
    if(t instanceof UnkNownHostException ||
       // XXX maybe a different msg ?     
       t instanceof SocketTimeoutException || 
       t instanceof noroutetoHostException ||
       t instanceof ConnectException) 
    {
        Bugzilla.LOG.log(Level.FINER,null,t);
        return NbBundle.getMessage(BugzillaExecutor.class,"MSG_HOST_NOT_FOUND");                   // NOI18N
    }
    String msg = getMessage(ce);
    if(msg != null) {
        msg = msg.trim().toLowerCase();
        if(HTTP_ERROR_NOT_FOUND.equals(msg)) {
            Bugzilla.LOG.log(Level.FINER,"returned error message [{0}]",msg);                     // NOI18N
            return NbBundle.getMessage(BugzillaExecutor.class,"MSG_HOST_NOT_FOUND");               // NOI18N
        }
    }
    return null;
}
项目:hekate    文件NettyClientHandler.java   
@Override
public void channelInactive(ChannelHandlerContext ctx) throws Exception {
    if (metrics != null) {
        metrics.ondisconnect();
    }

    if (state == CONNECTING) {
        state = disCONNECTED;

        ctx.fireExceptionCaught(new ConnectException("Got disconnected on handshake [channel=" + id + ']'));
    } else {
        state = disCONNECTED;

        super.channelInactive(ctx);
    }
}
项目:okwallet    文件PeerSocketHandler.java   
/** Catch any exceptions,logging them and then closing the channel. */
private void exceptionCaught(Exception e) {
    PeerAddress addr = getAddress();
    String s = addr == null ? "?" : addr.toString();
    if (e instanceof ConnectException || e instanceof IOException) {
        // Short message for network errors
        log.info(s + " - " + e.getMessage());
    } else {
        log.warn(s + " - ",e);
        Thread.UncaughtExceptionHandler handler = Threading.uncaughtExceptionHandler;
        if (handler != null)
            handler.uncaughtException(Thread.currentThread(),e);
    }

    close();
}
项目:hadoop-oss    文件TestRPC.java   
@Test
public void testClientWithoutServer() throws Exception {
  TestRpcService proxy;

  short invalidPort = 20;
  InetSocketAddress invalidAddress = new InetSocketAddress(ADDRESS,invalidPort);
  long invalidClientVersion = 1L;
  try {
    proxy = RPC.getProxy(TestRpcService.class,invalidClientVersion,invalidAddress,conf);
    // Test echo method
    proxy.echo(null,newEchoRequest("hello"));
    fail("We should not have reached here");
  } catch (ServiceException ioe) {
    //this is what we expected
    if (!(ioe.getCause() instanceof ConnectException)) {
      fail("We should not have reached here");
    }
  }
}
项目:wechat-api-java    文件HttpRequestUtil.java   
public static String doPost(String url,String json) throws Exception {
    try {
        CloseableHttpClient client = getHttpClient(url);
        HttpPost post = new HttpPost(url);
        config(post);
        logger.info("====> Executing request: " + post.getRequestLine());
        if (!StringUtils.isEmpty(json)) {
            StringEntity s = new StringEntity(json,"UTF-8");
            s.setContentEncoding("UTF-8");
            s.setContentType("application/json");
            post.setEntity(s);
        }
        String responseBody = client.execute(post,getStringResponseHandler());
        logger.info("====> Getting response from request " + post.getRequestLine() + " The responseBody: " + responseBody);
        return responseBody;
    } catch (Exception e) {
        if (e instanceof HttpHostConnectException || e.getCause() instanceof ConnectException) {
            throw new ConnectException("====> 连接服务器" + url + "失败: " + e.getMessage());
        }
        logger.error("====> HttpRequestUtil.doPost: " + e.getMessage(),e);
    }
    return null;
}
项目:RxRetrofit-tokean    文件retrywhenNetworkException.java   
@Override
public Observable<?> call(Observable<? extends Throwable> observable) {
    return observable
            .zipwith(Observable.range(1,count + 1),new Func2<Throwable,Integer,Wrapper>() {
                @Override
                public Wrapper call(Throwable throwable,Integer integer) {
                    return new Wrapper(throwable,integer);
                }
            }).flatMap(new Func1<Wrapper,Observable<?>>() {
                @Override
                public Observable<?> call(Wrapper wrapper) {
                    if ((wrapper.throwable instanceof ConnectException
                            || wrapper.throwable instanceof SocketTimeoutException
                            || wrapper.throwable instanceof TimeoutException)
                            && wrapper.index < count + 1) { //如果超出重试次数也抛出错误,否则认是会进入onCompleted
                        return Observable.timer(delay + (wrapper.index - 1) * increaseDelay,TimeUnit.MILLISECONDS);

                    }
                    return Observable.error(wrapper.throwable);
                }
            });
}
项目:TestChat    文件retrywhenNetWorkException.java   
@Override
public Observable<?> call(Observable<? extends Throwable> observable) {

        return observable.zipwith(Observable.range(1,retryCount + 1),ExceptionWrapper>() {
                @Override
                public ExceptionWrapper call(Throwable throwable,Integer integer) {
                        return new ExceptionWrapper(integer,throwable);
                }
        }).flatMap(new Func1<ExceptionWrapper,Observable<?>>() {
                @Override
                public Observable<?> call(ExceptionWrapper exceptionWrapper) {
                        if ((exceptionWrapper.throwable instanceof ConnectException ||
                                exceptionWrapper.throwable instanceof SocketException ||
                                exceptionWrapper.throwable instanceof TimeoutException) && exceptionWrapper.index < retryCount + 1) {
                                return Observable.timer(delayTime + (exceptionWrapper.index - 1) * delayTime,java.util.concurrent.TimeUnit.MILLISECONDS);
                        }
                        return Observable.error(exceptionWrapper.throwable);
                }
        });
}
项目:AntCloud    文件AntSubscriber.java   
@Override
public void onError(Throwable t) {
    if (t instanceof SocketTimeoutException
            || t instanceof InterruptedioException) {
        error(AntError.TIMEOUT_ERROR_CODE,"链接超时",t);
    } else if (t instanceof UnkNownHostException
            || t instanceof HttpException
            || t instanceof ConnectException) {
        error(AntError.NETWORK_ERROR_CODE,"网络异常",t);
    } else if (t instanceof JSONException
            || t instanceof JsonParseException
            || t instanceof ParseException) {
        error(AntError.PARSE_ERROR_CODE,"解析异常",t);
    } else {
        error(AntError.OTHER_ERROR_CODE,"其他异常",t);
    }
}
项目:oscm    文件BssClient.java   
public String resolveUsertoken(String usertoken,String saasId)
        throws servletexception,remoteexception {
    SessionServiceStub stub = new SessionServiceStub(getEndPoint(false));
    setBasicAuth(stub);
    SessionServiceStub.ResolveUserTokenE rut = new SessionServiceStub.ResolveUserTokenE();
    SessionServiceStub.ResolveUserToken param = new SessionServiceStub.ResolveUserToken();
    param.setSessionId(getSessionId(saasId));
    param.setUserToken(usertoken);
    param.setSubscriptionKey(getSubscriptionKey(saasId));
    rut.setResolveUserToken(param);
    try {
        ResolveUserTokenResponseE response = stub.resolveUserToken(rut);
        return response.getResolveUserTokenResponse().get_return();
    } catch (AxisFault e) {
        if (port < 8185 && searchPort
                && e.getDetail() instanceof ConnectException) {
            // try again with another port
            port++;
            return resolveUsertoken(usertoken,saasId);
        }
        throw new servletexception(e);
    }
}
项目:openjdk-jdk10    文件JMXStartStopTest.java   
private static void testNoConnect(int port,int rmiPort) throws Exception {
    try {
        testConnect(port,rmiPort);
        throw new Exception("Didn't expect the management agent running");
    } catch (Exception e) {
        Throwable t = e;
        while (t != null) {
            if (t instanceof remoteexception ||
                t instanceof SSLHandshakeException ||
                t instanceof ConnectException) {
                break;
            }
            t = t.getCause();
        }
        if (t == null) {
            throw new Exception("Unexpected exception",e);
        }
    }
}
项目:oscm-app    文件ProductProvisioningServicefactorybeanTest.java   
@Ignore
@Test(expected = ConnectException.class)
public void test_NoUser() throws Throwable {
    ServiceInstance instance = new ServiceInstance();
    ArrayList<InstanceParameter> params = new ArrayList<InstanceParameter>();
    params.add(PUBLIC_IP);
    params.add(WSDL);
    params.add(PROTOCOL);
    params.add(PORT);
    instance.setInstanceParameters(params);
    try {
        getInstance(instance);
    } catch (BadResultException e) {
        throw e.getCause();
    }
}
项目:oscm-app    文件ProductProvisioningServicefactorybeanTest.java   
@Ignore
@Test(expected = ConnectException.class)
public void test_nopassword() throws Throwable {
    ServiceInstance instance = new ServiceInstance();
    ArrayList<InstanceParameter> params = new ArrayList<InstanceParameter>();
    params.add(PUBLIC_IP);
    params.add(WSDL);
    params.add(PROTOCOL);
    params.add(PORT);
    params.add(USER);
    instance.setInstanceParameters(params);
    try {
        getInstance(instance);
    } catch (BadResultException e) {
        throw e.getCause();
    }
}
项目:oscm-app    文件ProductProvisioningServicefactorybeanTest.java   
@Ignore
@Test(expected = ConnectException.class)
public void test() throws Throwable {
    ServiceInstance instance = new ServiceInstance();
    ArrayList<InstanceParameter> params = new ArrayList<InstanceParameter>();
    params.add(PUBLIC_IP);
    params.add(WSDL);
    params.add(PROTOCOL);
    params.add(PORT);
    params.add(USER);
    params.add(USER_PWD);
    instance.setInstanceParameters(params);
    try {
        getInstance(instance);
    } catch (BadResultException e) {
        throw e.getCause();
    }
}
项目:My-Android-Base-Code    文件ErrorUtils.java   
public void checkerror(Throwable e){
    try {
        throwable = e;
        fireBaseReportError(e);
        Crashlytics.logException(e);
        e.printstacktrace();

        if (e instanceof HttpException) {
            int code = getHttpErrorCode(e);
            httpMessage(code);
        }
        else if (e instanceof ConnectException) {
            showToast(mContext.getString(R.string.slow_internet));
        } else if (e instanceof UnkNownHostException || e instanceof SocketTimeoutException) {
            showToast(mContext.getString(R.string.internet_not_connected));
        } else if (e instanceof SSLHandshakeException || e instanceof SSLPeerUnverifiedException) {
            showToast(mContext.getString(R.string.server_problem));
        } else {
            showToast(mContext.getString(R.string.unkNown_error_msg));
        }
    }
    catch (Exception err){
        err.printstacktrace();
    }
}
项目:jbase    文件BaSEObserver.java   
@Override
public void onError(@NonNull Throwable e) {
    LoadingDialog.dissmiss();
    String errMsg = "";
    if (e instanceof SocketTimeoutException) {
        errMsg = "网络连接超时,请检查您的网络状态,稍后重试";
    } else if (e instanceof ConnectException) {
        errMsg = "网络连接异常,请检查您的网络状态";
    } else if (e instanceof UnkNownHostException) {
        errMsg = "网络异常,请检查您的网络状态";
    } else {
        errMsg = e.getMessage();
    }
    LogUtils.i("onError:" + errMsg);
    _onError(errMsg);

}
项目:oscm    文件ProductProvisioningServicefactorybeanTest.java   
@Ignore
@Test(expected = ConnectException.class)
public void test_nopassword() throws Throwable {
    ServiceInstance instance = new ServiceInstance();
    ArrayList<InstanceParameter> params = new ArrayList<InstanceParameter>();
    params.add(PUBLIC_IP);
    params.add(WSDL);
    params.add(PROTOCOL);
    params.add(PORT);
    params.add(USER);
    instance.setInstanceParameters(params);
    try {
        getInstance(instance);
    } catch (BadResultException e) {
        throw e.getCause();
    }
}
项目:chromium-net-for-android    文件cronetUrlRequestTest.java   
@SmallTest
@Feature({"cronet"})
public void testUploadFailsWithoutinitializingStream() throws Exception {
    TestUrlRequestCallback callback = new TestUrlRequestCallback();
    // The port for PTP will always refuse a TCP connection
    UrlRequest.Builder builder = new UrlRequest.Builder("http://127.0.0.1:319",callback,callback.getExecutor(),mTestFramework.mcronetEngine);

    TestUploadDataProvider dataProvider = new TestUploadDataProvider(
            TestUploadDataProvider.SuccessCallbackMode.SYNC,callback.getExecutor());
    dataProvider.addRead("test".getBytes());
    builder.setUploadDataProvider(dataProvider,callback.getExecutor());
    builder.addHeader("Content-Type","useless/string");
    builder.build().start();
    callback.blockForDone();
    dataProvider.assertClosed();

    assertNull(callback.mResponseInfo);
    if (testingJavaimpl()) {
        Throwable cause = callback.mError.getCause();
        assertTrue("Exception was: " + cause,cause instanceof ConnectException);
    } else {
        assertEquals("Exception in cronetUrlRequest: net::ERR_CONNECTION_REFUSED",callback.mError.getMessage());
    }
}
项目:aceql-http    文件WebServerApi.java   
/**
    * Stops the embedded Web server running on the designated port.
    * 
    * @param port
    *            the port on which the sql Web server is running
    * 
    * @throws IOException
    *             if the semaphore file (that signals to the Web Server to
    *             stop) can not be created
    */
   public void stopServer(int port) throws IOException {

PortSemaphoreFile portSemaphoreFile = new PortSemaphoreFile(port);

if (! portSemaphoreFile.exists()) {
    throw new ConnectException("WARNING! There is no " + Version.PRODUCT.NAME + " Web server running on port " + port); 
}

// Always Force the deletion of the semaphore file:
try {
    portSemaphoreFile.delete();
} catch (IOException ioe) {
    throw new IOException(
        "Can not stop the Web server. Please delete manually the semaphore file "
            + portSemaphoreFile.getSemaphoreFile()
            + " and then retry. ",ioe);
}

if (TomcatStarterUtil.available(port)) {        
    throw new ConnectException("WARNING! There is no sql Web server running on port " + port); 
}

   }
项目:osc-core    文件ServerControl.java   
private static boolean isRunningServer() {
    try {
        log.info("Check if server is running ...");
        VmidcServerRestClient restClient = new VmidcServerRestClient("localhost",apiPort,VMIDC_DEFAULT_LOGIN,VMIDC_DEFAULT_PASS,true);

        ServerStatusResponse res = getServerStatusResponse(restClient);

        String oldPid = res.getPid();

        log.warn("Current pid:" + ServerUtil.getCurrentPid() + ". Running server (pid:" + oldPid + ") version: "
                + res.getVersion() + " with db version: " + res.getDbVersion());

        return true;
    } catch (ProcessingException | ConnectException e1) {
        log.warn("Fail to connect to running server: "+ e1.getMessage());
    } catch (Exception ex) {
        log.warn("Fail to connect to running server. Assuming not running: " + ex);
    }

    return false;
}
项目:simulacron    文件ServerTest.java   
@Test
public void testStopAndStart() throws Exception {
  try (BoundNode boundNode = localServer.register(NodeSpec.builder());
      MockClient client = new MockClient(eventLoop)) {
    client.connect(boundNode.getAddress());
    client.write(new Startup());

    // sleep a little bit as connected channels may not be registered immediately.
    Thread.sleep(50);
    NodeConnectionReport report = boundNode.getConnections();
    assertthat(report.getConnections()).hasSize(1);

    // stop the node,connection should close.
    boundNode.stop();
    report = boundNode.getConnections();
    assertthat(report.getConnections()).hasSize(0);

    // attempt to connect should fail
    try {
      client.connect(boundNode.getAddress());
      fail("Should not have been able to connect");
    } catch (ConnectException ce) {
      // expected
    }

    // start the node
    boundNode.start();

    // attempt to connect should succeed
    client.connect(boundNode.getAddress());

    // sleep a little bit as connected channels may not be registered immediately.
    Thread.sleep(50);

    report = boundNode.getConnections();
    assertthat(report.getConnections()).hasSize(1);
  }
}
项目:OSchina_resources_android    文件AppException.java   
public static AppException io(Exception e,int code) {
    if (e instanceof UnkNownHostException || e instanceof ConnectException) {
        return new AppException(TYPE_NETWORK,code,e);
    } else if (e instanceof IOException) {
        return new AppException(TYPE_IO,e);
    }
    return run(e);
}
项目:ditb    文件PreemptiveFastFailInterceptor.java   
/**
 * Check if the exception is something that indicates that we cannot
 * contact/communicate with the server.
 *
 * @param e
 * @return true when exception indicates that the client wasn't able to make contact with server
 */
private boolean isConnectionException(Throwable e) {
  if (e == null)
    return false;
  // This list covers most connectivity exceptions but not all.
  // For example,in SocketoutputStream a plain IOException is thrown
  // at times when the channel is closed.
  return (e instanceof SocketTimeoutException
      || e instanceof ConnectException || e instanceof ClosedChannelException
      || e instanceof SyncFailedException || e instanceof EOFException
      || e instanceof TimeoutException
      || e instanceof ConnectionClosingException || e instanceof FailedServerException);
}
项目:JInsight    文件AbstractHttpClientInstrumentationTest.java   
@Test
public void testConnectErrors() throws Exception {
  Snapshot expectedCounts = tracker.snapshot();
  HttpGet request = new HttpGet("http://0.0.0.0/asd");
  HttpResponse response = null;
  try {
    response = httpclient.execute(request);
  } catch (ConnectException e) {
    //expected ... hence assertNull(response)
  }
  assertNull(response);
  tracker.validate(expectedCounts);//validate no metrics change
}
项目:angel    文件MLRPC.java   
/**
 * @param retries current retried times.
 * @param maxAttmpts max attempts
 * @param protocol protocol interface
 * @param addr address of remote service
 * @param ce ConnectException
 * @throws RetriesExhaustedException
 */
private static void handleConnectionException(int retries,int maxAttmpts,Class<?> protocol,InetSocketAddress addr,ConnectException ce) throws RetriesExhaustedException {
  if (maxAttmpts >= 0 && retries >= maxAttmpts) {
    LOG.info("Server at " + addr + " Could not be reached after " + maxAttmpts
        + " tries,giving up.");
    throw new RetriesExhaustedException("Failed setting up proxy " + protocol + " to "
        + addr.toString() + " after attempts=" + maxAttmpts,ce);
  }
}
项目:GitHub    文件ExceptionEngine.java   
public static ApiException handleException(Throwable e) {
    ApiException ex;
    if (e instanceof HttpException) {             //HTTP错误
        HttpException httpExc = (HttpException) e;
        ex = new ApiException(e,httpExc.code());
        ex.setMsg("网络错误");  //均视为网络错误
        return ex;
    } else if (e instanceof ServerException) {    //服务器返回的错误
        ServerException serverExc = (ServerException) e;
        ex = new ApiException(serverExc,serverExc.getCode());
        ex.setMsg(serverExc.getMsg());
        return ex;
    } else if (e instanceof JsonParseException
            || e instanceof JSONException
            || e instanceof ParseException || e instanceof MalformedJsonException) {  //解析数据错误
        ex = new ApiException(e,ANALYTIC_SERVER_DATA_ERROR);
        ex.setMsg("解析错误");
        return ex;
    } else if (e instanceof ConnectException) {//连接网络错误
        ex = new ApiException(e,CONNECT_ERROR);
        ex.setMsg("连接失败");
        return ex;
    } else if (e instanceof SocketTimeoutException) {//网络超时
        ex = new ApiException(e,TIME_OUT_ERROR);
        ex.setMsg("网络超时");
        return ex;
    } else {  //未知错误
        ex = new ApiException(e,UN_KNowN_ERROR);
        ex.setMsg("未知错误");
        return ex;
    }
}
项目:teamcity-msteams-notifier    文件MsTeamsNotificationTest.java   
@Ignore
@Test(expected=java.net.ConnectException.class)
public void test_ConnectionRefused() throws ConnectException,IOException{
    MsTeamsNotification w = factory.getMsTeamsNotification();
    w.setEnabled(true);
    w.post();       
}
项目:slacklet    文件SlackWebSocketSessionImpl.java   
private void connectImpl() throws IOException
{
    LOGGER.info("connecting to slack");
    HttpClient httpClient = getHttpClient();
    HttpGet request = new HttpGet(SLACK_HTTPS_AUTH_URL + authToken);
    HttpResponse response;
    response = httpClient.execute(request);
    LOGGER.debug(response.getStatusLine().toString());
    String jsonResponse = consumetoString(response.getEntity().getContent());
    SlackJSONSessionStatusParser sessionParser = new SlackJSONSessionStatusParser(jsonResponse);
    sessionParser.parse();
    if (sessionParser.getError() != null)
    {
        LOGGER.error("Error during authentication : " + sessionParser.getError());
        throw new ConnectException(sessionParser.getError());
    }

    users = sessionParser.getUsers();
    integrations = sessionParser.getIntegrations();
    channels = sessionParser.getChannels();
    sessionPersona = sessionParser.getSessionPersona();
    team = sessionParser.getTeam();
    LOGGER.info("Team " + team.getId() + " : " + team.getName());
    LOGGER.info("Self " + sessionPersona.getId() + " : " + sessionPersona.getUserName());
    LOGGER.info(users.size() + " users found on this session");
    LOGGER.info(channels.size() + " channels found on this session");
    webSocketConnectionURL = sessionParser.getWebSocketURL();
    LOGGER.debug("retrieved websocket URL : " + webSocketConnectionURL);
    establishWebsocketConnection();
}

版权声明:本文内容由互联网用户自发贡献,该文观点与技术仅代表作者本人。本站仅提供信息存储空间服务,不拥有所有权,不承担相关法律责任。如发现本站有涉嫌侵权/违法违规的内容, 请发送邮件至 [email protected] 举报,一经查实,本站将立刻删除。