• 设为首页
  • 点击收藏
  • 手机版
    手机扫一扫访问
    迪恩网络手机版
  • 关注官方公众号
    微信扫一扫关注
    迪恩网络公众号

Java ClientBuilder类代码示例

原作者: [db:作者] 来自: [db:来源] 收藏 邀请

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



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

示例1: makeMemcachedClient

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
/**
 * Constructs a finagle java memcached client for the list of endpoints..
 *
 * @param endpoints list of {@code InetSocketAddress} for all the memcached servers.
 * @return {@link Client} to read/write to the hash ring of the servers..
 */
static Client makeMemcachedClient(Options opts, List<InetSocketAddress> endpoints)
    throws UnknownHostException {
  com.twitter.finagle.memcached.Client client =
      KetamaClientBuilder.get()
          .nodes(getHostPortWeightTuples(endpoints))
          .clientBuilder(ClientBuilder.get()
                             .codec(new Memcached())
                             .tcpConnectTimeout(new Duration(TimeUnit.MILLISECONDS.toNanos(opts.connectTimeoutMillis)))
                             .requestTimeout(new Duration(TimeUnit.MILLISECONDS.toNanos(opts.requestTimeoutMillis)))
                             .timeout(new Duration(TimeUnit.MILLISECONDS.toNanos(opts.e2eTimeoutMillis)))
                             .hostConnectionLimit(opts.hostConnectionLimit)
                             .hostConnectionMaxWaiters(opts.maxWaiters)
                             .retries(opts.requestRetries))
          .build();

  return new ClientBase(client);
}
 
开发者ID:redBorder,项目名称:rb-bi,代码行数:24,代码来源:MemcachedState.java


示例2: testBuildClientsFromSameBuilder

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
@Test(timeout = 60000)
public void testBuildClientsFromSameBuilder() throws Exception {
    DistributedLogClientBuilder builder = DistributedLogClientBuilder.newBuilder()
            .name("build-clients-from-same-builder")
            .clientId(ClientId$.MODULE$.apply("test-builder"))
            .finagleNameStr("inet!127.0.0.1:7001")
            .streamNameRegex(".*")
            .handshakeWithClientInfo(true)
            .clientBuilder(ClientBuilder.get()
                .hostConnectionLimit(1)
                .connectTimeout(Duration.fromSeconds(1))
                .tcpConnectTimeout(Duration.fromSeconds(1))
                .requestTimeout(Duration.fromSeconds(10)));
    DistributedLogClient client1 = builder.build();
    DistributedLogClient client2 = builder.build();
    assertFalse(client1 == client2);
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:18,代码来源:TestDistributedLogClientBuilder.java


示例3: testChecksumFlag

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
/**
 * Sanity check to make sure both checksum flag values work.
 */
@Test(timeout = 60000)
public void testChecksumFlag() throws Exception {
    String name = "dlserver-basic-write";
    LocalRoutingService routingService = LocalRoutingService.newBuilder().build();
    routingService.addHost(name, dlServer.getAddress());
    DistributedLogClientBuilder dlClientBuilder = DistributedLogClientBuilder.newBuilder()
        .name(name)
        .clientId(ClientId$.MODULE$.apply("test"))
        .routingService(routingService)
        .handshakeWithClientInfo(true)
        .clientBuilder(ClientBuilder.get()
            .hostConnectionLimit(1)
            .connectionTimeout(Duration.fromSeconds(1))
            .requestTimeout(Duration.fromSeconds(60)))
        .checksum(false);
    DistributedLogClient dlClient = (DistributedLogClientImpl) dlClientBuilder.build();
    Await.result(dlClient.write(name, ByteBuffer.wrap(("1").getBytes())));
    dlClient.close();

    dlClient = dlClientBuilder.checksum(true).build();
    Await.result(dlClient.write(name, ByteBuffer.wrap(("2").getBytes())));
    dlClient.close();
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:27,代码来源:TestDistributedLogServer.java


示例4: TwoRegionDLClient

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
protected TwoRegionDLClient(String name, Map<SocketAddress, String> regionMap) {
    localRoutingService = new LocalRoutingService();
    remoteRoutingService = new LocalRoutingService();
    RegionsRoutingService regionsRoutingService =
            RegionsRoutingService.of(new DefaultRegionResolver(regionMap),
                    localRoutingService, remoteRoutingService);
    dlClientBuilder = DistributedLogClientBuilder.newBuilder()
                .name(name)
                .clientId(ClientId$.MODULE$.apply(name))
                .routingService(regionsRoutingService)
                .streamNameRegex(".*")
                .handshakeWithClientInfo(true)
                .maxRedirects(2)
                .clientBuilder(ClientBuilder.get()
                    .hostConnectionLimit(1)
                    .connectionTimeout(Duration.fromSeconds(1))
                    .requestTimeout(Duration.fromSeconds(10)));
    dlClient = (DistributedLogClientImpl) dlClientBuilder.build();
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:20,代码来源:DistributedLogServerTestCase.java


示例5: newBuilder

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
public static Builder newBuilder(String clientName,
                                 ClientId clientId,
                                 ClientBuilder clientBuilder,
                                 ClientConfig clientConfig,
                                 ClientStats clientStats) {
    return new DefaultBuilder(clientName, clientId, clientBuilder, clientConfig, clientStats);
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:8,代码来源:ProxyClient.java


示例6: DefaultBuilder

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
private DefaultBuilder(String clientName,
                       ClientId clientId,
                       ClientBuilder clientBuilder,
                       ClientConfig clientConfig,
                       ClientStats clientStats) {
    this.clientName = clientName;
    this.clientId = clientId;
    this.clientStats = clientStats;
    // client builder
    ClientBuilder builder = setDefaultSettings(null == clientBuilder ? getDefaultClientBuilder() : clientBuilder);
    if (clientConfig.getThriftMux()) {
        builder = enableThriftMux(builder, clientId);
    }
    this.clientBuilder = builder;
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:16,代码来源:ProxyClient.java


示例7: getDefaultClientBuilder

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
private ClientBuilder getDefaultClientBuilder() {
    return ClientBuilder.get()
        .hostConnectionLimit(1)
        .tcpConnectTimeout(Duration.fromMilliseconds(200))
        .connectTimeout(Duration.fromMilliseconds(200))
        .requestTimeout(Duration.fromSeconds(1));
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:8,代码来源:ProxyClient.java


示例8: setDefaultSettings

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
@SuppressWarnings("unchecked")
private ClientBuilder setDefaultSettings(ClientBuilder builder) {
    return builder.name(clientName)
           .codec(ThriftClientFramedCodec.apply(Option.apply(clientId)))
           .failFast(false)
           .noFailureAccrual()
           // disable retries on finagle client builder, as there is only one host per finagle client
           // we should throw exception immediately on first failure, so DL client could quickly detect
           // failures and retry other proxies.
           .retries(1)
           .keepAlive(true);
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:13,代码来源:ProxyClient.java


示例9: build

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
@Override
@SuppressWarnings("unchecked")
public ProxyClient build(SocketAddress address) {
    Service<ThriftClientRequest, byte[]> client =
        ClientBuilder.safeBuildFactory(
                clientBuilder
                        .hosts((InetSocketAddress) address)
                        .reportTo(clientStats.getFinagleStatsReceiver(address))
        ).toService();
    DistributedLogService.ServiceIface service =
            new DistributedLogService.ServiceToClient(client, new TBinaryProtocol.Factory());
    return new ProxyClient(address, client, service);
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:14,代码来源:ProxyClient.java


示例10: createDistributedLogClientBuilder

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
static DistributedLogClientBuilder createDistributedLogClientBuilder(ServerSet serverSet) {
    return DistributedLogClientBuilder.newBuilder()
                    .name("rebalancer_tool")
                    .clientId(ClientId$.MODULE$.apply("rebalancer_tool"))
                    .maxRedirects(2)
                    .serverSet(serverSet)
                    .clientBuilder(ClientBuilder.get()
                            .connectionTimeout(Duration.fromSeconds(2))
                            .tcpConnectTimeout(Duration.fromSeconds(2))
                            .requestTimeout(Duration.fromSeconds(10))
                            .hostConnectionLimit(1)
                            .hostConnectionCoresize(1)
                            .keepAlive(true)
                            .failFast(false));
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:16,代码来源:BalancerTool.java


示例11: runCmd

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
@Override
protected int runCmd(CommandLine commandLine) throws Exception {
    try {
        parseCommandLine(commandLine);
    } catch (ParseException pe) {
        System.err.println("ERROR: failed to parse commandline : '" + pe.getMessage() + "'");
        printUsage();
        return -1;
    }

    DLZkServerSet serverSet = DLZkServerSet.of(uri, 60000);
    logger.info("Created serverset for {}", uri);
    try {
        DistributedLogClient client = DistributedLogClientBuilder.newBuilder()
                .name("proxy_tool")
                .clientId(ClientId$.MODULE$.apply("proxy_tool"))
                .maxRedirects(2)
                .serverSet(serverSet.getServerSet())
                .clientBuilder(ClientBuilder.get()
                    .connectionTimeout(Duration.fromSeconds(2))
                    .tcpConnectTimeout(Duration.fromSeconds(2))
                    .requestTimeout(Duration.fromSeconds(10))
                    .hostConnectionLimit(1)
                    .hostConnectionCoresize(1)
                    .keepAlive(true)
                    .failFast(false))
                .build();
        try {
            return runCmd(client);
        } finally {
            client.close();
        }
    } finally {
        serverSet.close();
    }
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:37,代码来源:ProxyTool.java


示例12: DLClient

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
protected DLClient(String name, String streamNameRegex) {
    routingService = LocalRoutingService.newBuilder().build();
    dlClientBuilder = DistributedLogClientBuilder.newBuilder()
                .name(name)
                .clientId(ClientId$.MODULE$.apply(name))
                .routingService(routingService)
                .streamNameRegex(streamNameRegex)
                .handshakeWithClientInfo(true)
                .clientBuilder(ClientBuilder.get()
                    .hostConnectionLimit(1)
                    .connectionTimeout(Duration.fromSeconds(1))
                    .requestTimeout(Duration.fromSeconds(60)));
    dlClient = (DistributedLogClientImpl) dlClientBuilder.build();
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:15,代码来源:DistributedLogServerTestCase.java


示例13: PinLaterClient

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
public PinLaterClient(String host, int port, int concurrency) {
  this.service = ClientBuilder.safeBuild(
      ClientBuilder.get()
          .hosts(new InetSocketAddress(host, port))
          .codec(ThriftClientFramedCodec.apply(Option.apply(new ClientId("pinlaterclient"))))
          .hostConnectionLimit(concurrency)
          .tcpConnectTimeout(Duration.apply(2, TimeUnit.SECONDS))
          .requestTimeout(Duration.apply(10, TimeUnit.SECONDS))
          .retries(1));
  this.iface = new PinLater.ServiceToClient(service, new TBinaryProtocol.Factory());
}
 
开发者ID:pinterest-attic,项目名称:pinlater,代码行数:12,代码来源:PinLaterClient.java


示例14: getClientFuture

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
protected Future<TerrapinServerInternal.ServiceIface> getClientFuture(final String hostName) {
  return connectionfuturePool.apply(new Function0<TerrapinServerInternal.ServiceIface>() {
    @Override
    public TerrapinServerInternal.ServiceIface apply() {
      Pair<Service<ThriftClientRequest, byte[]>, TerrapinServerInternal.ServiceIface> client =
          thriftClientCache.getIfPresent(hostName);
      if (client == null) {
        Service<ThriftClientRequest, byte[]> service = ClientBuilder.safeBuild(
            ClientBuilder.get()
                .hosts(new InetSocketAddress(hostName, targetPort))
                .codec(new ThriftClientFramedCodecFactory(Option.<ClientId>empty()))
                .retries(1)
                .connectTimeout(Duration.fromMilliseconds(connectTimeoutMs))
                .requestTimeout(Duration.fromMilliseconds(timeoutMs))
                .hostConnectionLimit(100)
                .failFast(false));

        client = new ImmutablePair(service, new TerrapinServerInternal.ServiceToClient(
            service, new TBinaryProtocol.Factory()));
        // A release is automatically called when an element is kicked out as part of the
        // removal listener. Doing a double release causes other issues.
        thriftClientCache.asMap().putIfAbsent(hostName, client);
      }
      return client.getRight();
    }
  });
}
 
开发者ID:pinterest-attic,项目名称:terrapin,代码行数:28,代码来源:TerrapinClient.java


示例15: GeneratorMaster

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
public GeneratorMaster() {
    redisCache = new RedisCache("localhost", 7000);

    String propertiesPath = "/videogenmaster.properties";
    PropertyPlaceholder propsHolder = new PropertyPlaceholder(propertiesPath);
    propsHolder.generatePropertyMap();
    Map<String, String> props = propsHolder.getPropertyMap();

    videoCacheUpdatePool = Executors.newFixedThreadPool(Integer.parseInt(props.get("maxThreads")));
    videoCacheUpdateTimer = new Timer();
    /*videoCacheUpdateTimer.schedule(new VideoCache(videoCacheUpdatePool, propsHolder, client), 
            5000, 5000);*/

    stats = new Statistics();

    RetryPolicy<Try<Nothing$>> retryPolicy = new SimpleRetryPolicy<Try<Nothing$>>() {

        @Override
        public Duration backoffAt(int retryCount) {
            if (retryCount > 3) {
                return Duration.fromSeconds(16);
            }
            return Duration.fromSeconds((int) Math.pow(2.0, retryCount));
        }

        @Override
        public boolean shouldRetry(Try<Nothing$> arg) {
            return true;
        }
    };

    ClientBuilder clientBuilder = ClientBuilder.get()
            .codec(com.twitter.finagle.http.Http.get())
            .retryPolicy(retryPolicy) // Retry forever, with exponential backoff <= 16
            .hostConnectionLimit(500)
            .hosts("localhost:" + SLAVE_PORT);
    client = ClientBuilder.safeBuild(clientBuilder);
    // client = Http.newService("localhost:8001");
}
 
开发者ID:eternalthinker,项目名称:finagle-java-example-master-slave,代码行数:40,代码来源:GeneratorMaster.java


示例16: GeneratorSlave

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
public GeneratorSlave() {
    ExecutorService pool = Executors.newFixedThreadPool(20);
    futurePool = new ExecutorServiceFuturePool(pool);
    stats = new SlaveStatistics();
    //client = Http.newService("localhost:8000");
    client = ClientBuilder
            .safeBuild(ClientBuilder.get().codec(com.twitter.finagle.http.Http.get())
                    .hosts(":8000").hostConnectionLimit(500));

}
 
开发者ID:eternalthinker,项目名称:finagle-java-example-master-slave,代码行数:11,代码来源:GeneratorSlave.java


示例17: SimpleKestrelClient

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
/**
 * initialise a {@link Client} instance using {@link ServiceFactory} from a
 * {@link ClientBuilder}
 *
 * @param addr
 */
public SimpleKestrelClient(InetSocketAddress addr) {
	final ClientBuilder<Command, Response, Yes, Yes, Yes> builder = ClientBuilder.get()
			.codec(Kestrel.get())
			.hosts(addr)
			.hostConnectionLimit(1);
	final ServiceFactory<Command, Response> kestrelClientBuilder = ClientBuilder.safeBuildFactory(builder);
	client = Client.newInstance(kestrelClientBuilder);
}
 
开发者ID:openimaj,项目名称:openimaj,代码行数:15,代码来源:SimpleKestrelClient.java


示例18: enableThriftMux

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
@SuppressWarnings("unchecked")
private ClientBuilder enableThriftMux(ClientBuilder builder, ClientId clientId) {
    return builder.stack(ThriftMux.client().withClientId(clientId));
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:5,代码来源:ProxyClient.java


示例19: DistributedLogClientImpl

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
public DistributedLogClientImpl(String name,
                                ClientId clientId,
                                RoutingService routingService,
                                ClientBuilder clientBuilder,
                                ClientConfig clientConfig,
                                StatsReceiver statsReceiver,
                                StatsReceiver streamStatsReceiver,
                                RegionResolver regionResolver,
                                boolean enableRegionStats) {
    this.clientName = name;
    this.clientId = clientId;
    this.routingService = routingService;
    this.clientConfig = clientConfig;
    this.streamFailfast = clientConfig.getStreamFailfast();
    this.streamNameRegexPattern = Pattern.compile(clientConfig.getStreamNameRegex());
    this.regionResolver = regionResolver;
    // Build the timer
    this.dlTimer = new HashedWheelTimer(
            new ThreadFactoryBuilder().setNameFormat("DLClient-" + name + "-timer-%d").build(),
            this.clientConfig.getRedirectBackoffStartMs(),
            TimeUnit.MILLISECONDS);
    // register routing listener
    this.routingService.registerListener(this);
    // build the ownership cache
    this.ownershipCache = new OwnershipCache(this.clientConfig, this.dlTimer, statsReceiver, streamStatsReceiver);
    // Client Stats
    this.clientStats = new ClientStats(statsReceiver, enableRegionStats, regionResolver);
    // Client Manager
    this.clientBuilder = ProxyClient.newBuilder(clientName, clientId, clientBuilder, clientConfig, clientStats);
    this.clientManager = new ProxyClientManager(
            this.clientConfig,  // client config
            this.clientBuilder, // client builder
            this.dlTimer,       // timer
            this,               // host provider
            clientStats);       // client stats
    this.clientManager.registerProxyListener(this);

    // Cache Stats
    StatsReceiver cacheStatReceiver = statsReceiver.scope("cache");
    Seq<String> numCachedStreamsGaugeName =
            scala.collection.JavaConversions.asScalaBuffer(Arrays.asList("num_streams")).toList();
    cacheStatReceiver.provideGauge(numCachedStreamsGaugeName, new Function0<Object>() {
        @Override
        public Object apply() {
            return (float) ownershipCache.getNumCachedStreams();
        }
    });
    Seq<String> numCachedHostsGaugeName =
            scala.collection.JavaConversions.asScalaBuffer(Arrays.asList("num_hosts")).toList();
    cacheStatReceiver.provideGauge(numCachedHostsGaugeName, new Function0<Object>() {
        @Override
        public Object apply() {
            return (float) clientManager.getNumProxies();
        }
    });

    logger.info("Build distributedlog client : name = {}, client_id = {}, routing_service = {}, stats_receiver = {}, thriftmux = {}",
                new Object[] { name, clientId, routingService.getClass(), statsReceiver.getClass(), clientConfig.getThriftMux() });
}
 
开发者ID:twitter,项目名称:distributedlog,代码行数:60,代码来源:DistributedLogClientImpl.java


示例20: loadFileSetData

import com.twitter.finagle.builder.ClientBuilder; //导入依赖的package包/类
/**
 * Attempt to load data (already in HDFS on a correct directory) into an already locked fileset.
 * The data is assumed to already have been placed in the correct directory on the terrapin
 * cluster. This is being called by the Terrapin loader jobs. The @fsInfo object is the same
 * as the locked fsInfo object.
 */
public static void loadFileSetData(ZooKeeperManager zkManager, FileSetInfo fsInfo, Options options)
    throws Exception {
    InetSocketAddress controllerSockAddress = zkManager.getControllerLeader();
    LOG.info("Connecting to controller at " +
            controllerSockAddress.getHostName() + ":" + controllerSockAddress.getPort());
    LOG.info("Load timeout " + Constants.LOAD_TIMEOUT_SECONDS + " seconds.");

    Service<ThriftClientRequest, byte[]> service = ClientBuilder.safeBuild(ClientBuilder.get()
            .hosts(controllerSockAddress)
            .codec(new ThriftClientFramedCodecFactory(Option.<ClientId>empty()))
            .retries(1)
            .connectTimeout(Duration.fromMilliseconds(1000))
            .requestTimeout(Duration.fromSeconds(Constants.LOAD_TIMEOUT_SECONDS))
            .hostConnectionLimit(100)
            .failFast(false));
    TerrapinController.ServiceIface iface = new TerrapinController.ServiceToClient(
            service, new TBinaryProtocol.Factory());
    TerrapinLoadRequest request = new TerrapinLoadRequest();
    request.setHdfsDirectory(fsInfo.servingInfo.hdfsPath);
    request.setOptions(options);
    request.setFileSet(fsInfo.fileSetName);
    request.setExpectedNumPartitions(fsInfo.servingInfo.numPartitions);

    LOG.info("Loading file set " + fsInfo.fileSetName + " at " + fsInfo.servingInfo.hdfsPath);
    long startTimeSeconds = System.currentTimeMillis() / 1000;
    int numTriesLeft = 5;
    boolean done = false;
    Exception e = null;
    while (numTriesLeft > 0) {
        try {
            iface.loadFileSet(request).get();
            done = true;
            break;
        } catch (Throwable t) {
            LOG.error("Swap failed with exception.", t);
            e = new Exception(t);
            numTriesLeft--;
        }
        LOG.info("Retrying in 10 seconds.");
        try {
            Thread.sleep(10000);
        } catch (InterruptedException ie) {
            LOG.error("Interrupted.");
            break;
        }
    }
    if (done) {
        LOG.info("Load successful. Swap took " +
                ((System.currentTimeMillis() / 1000) - startTimeSeconds) + " seconds.");
    } else {
        LOG.error("Load failed !!!.");
        throw new Exception(e);
    }
}
 
开发者ID:pinterest-attic,项目名称:terrapin,代码行数:61,代码来源:TerrapinUtil.java



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


鲜花

握手

雷人

路过

鸡蛋
该文章已有0人参与评论

请发表评论

全部评论

专题导读
上一篇:
Java Field类代码示例发布时间:2022-05-23
下一篇:
Java Context类代码示例发布时间:2022-05-23
热门推荐
阅读排行榜

扫描微信二维码

查看手机版网站

随时了解更新最新资讯

139-2527-9053

在线客服(服务时间 9:00~18:00)

在线QQ客服
地址:深圳市南山区西丽大学城创智工业园
电邮:jeky_zhao#qq.com
移动电话:139-2527-9053

Powered by 互联科技 X3.4© 2001-2213 极客世界.|Sitemap