Warning: file_get_contents(/data/phpspider/zhask/data//catemap/9/java/355.json): failed to open stream: No such file or directory in /data/phpspider/zhask/libs/function.php on line 167

Warning: Invalid argument supplied for foreach() in /data/phpspider/zhask/libs/tag.function.php on line 1116

Notice: Undefined index: in /data/phpspider/zhask/libs/function.php on line 180

Warning: array_chunk() expects parameter 1 to be array, null given in /data/phpspider/zhask/libs/function.php on line 181

Warning: file_get_contents(/data/phpspider/zhask/data//catemap/3/sockets/2.json): failed to open stream: No such file or directory in /data/phpspider/zhask/libs/function.php on line 167

Warning: Invalid argument supplied for foreach() in /data/phpspider/zhask/libs/tag.function.php on line 1116

Notice: Undefined index: in /data/phpspider/zhask/libs/function.php on line 180

Warning: array_chunk() expects parameter 1 to be array, null given in /data/phpspider/zhask/libs/function.php on line 181
Java 返回速率; } /** *生成消息摘要并通过连接的套接字发送 *每次需要发送时是否打开新连接? *@抛出异常 */ public void sendMessageDigest()引发IOException { initConnection(); //生成消_Java_Sockets_Networking_Channel - Fatal编程技术网

Java 返回速率; } /** *生成消息摘要并通过连接的套接字发送 *每次需要发送时是否打开新连接? *@抛出异常 */ public void sendMessageDigest()引发IOException { initConnection(); //生成消

Java 返回速率; } /** *生成消息摘要并通过连接的套接字发送 *每次需要发送时是否打开新连接? *@抛出异常 */ public void sendMessageDigest()引发IOException { initConnection(); //生成消,java,sockets,networking,channel,Java,Sockets,Networking,Channel,返回速率; } /** *生成消息摘要并通过连接的套接字发送 *每次需要发送时是否打开新连接? *@抛出异常 */ public void sendMessageDigest()引发IOException { initConnection(); //生成消息 字节[]数据=generateMessageDigest(); //准备数据 buffer.clear(); buffer.put(数据); 这个.selector.wakeup(); } /** *消息的实际书写是否正确 *@param

返回速率; } /** *生成消息摘要并通过连接的套接字发送 *每次需要发送时是否打开新连接? *@抛出异常 */ public void sendMessageDigest()引发IOException { initConnection(); //生成消息 字节[]数据=generateMessageDigest(); //准备数据 buffer.clear(); buffer.put(数据); 这个.selector.wakeup(); } /** *消息的实际书写是否正确 *@param SelectionKey表示正在写入的频道的密钥 */ 私有无效写入(SelectionKey)引发IOException { SocketChannel SocketChannel=(SocketChannel)key.channel(); socketChannel.write(缓冲区); System.out.println(“将数据写入服务器…”); key.interesttops(SelectionKey.OP_READ);//现在对编写不感兴趣--等待来自服务器的消息 } 公开募捐 { while(true) { 试一试{ //处理套接字通道op更改 processChangeRequests(); this.selector.select(); //获取已准备好的通道的密钥集 迭代器keyIterator=选择器.selectedKeys().Iterator(); while(keyIterator.hasNext()){ //自己拿钥匙 SelectionKey=keyIterator.next(); keyterator.remove(); //System.out.println(key.interesttops()); //避免使用无效密钥 如果(!key.isValid()) { 继续; } if(key.isConnectable()){ 此。完成连接(键); }else if(key.isReadable()){ 此.readData(键); }else if(key.isWritable()){ 这个。写(键); } } }catch(异常e){e.printStackTrace();} } } /** *方法,该方法将在处理选择键之前需要对其进行的更改排入队列 *当多个线程需要更改选择键时,这非常有用 *XXX:当调用方不是选择线程时使用 */ 私有void processChangeRequests()引发IOException { 已同步(此.changeRequests) { Iterator changes=this.changeRequests.Iterator(); while(changes.hasNext()) { ChangeRequest ChangeRequest=changes.next(); 开关(changeRequest.type) { 案例(ChangeRequest.CHANGE\u OP): changeRequest.channel.keyFor(this.selector).interestOps(changeRequest.ops); 打破 case ChangeRequest.REGISTER: changeRequest.channel.register(this.selector,changeRequest.ops); 打破 } } this.changeRequests.clear(); } } /** *在指定的ip地址和端口上初始化套接字通道 *将其配置为非阻塞 *@param-ipAddress *@param端口 *@抛出异常 */ 私有void initConnection()引发IOException { SocketChannel SocketChannel=SocketChannel.open(); socketChannel.configureBlocking(假); socketChannel.connect(this.serverSocketAddress); //发出请求是因为选择线程不是此函数的调用方 已同步(此.changeRequests){ this.changeRequests.add(新的ChangeRequest(socketChannel,ChangeRequest.REGISTER,SelectionKey.OP_CONNECT)); } } /** *通过在通道上调用finishConnect()并将其设置为OP_WRITE来完成连接 *@param-key */ private void finishConnection(选择密钥) { //已与远程服务器建立连接。 SocketChannel SocketChannel=(SocketChannel)key.channel(); //完成连接。如果连接操作失败 //这将引发IOException。 试一试{ socketChannel.finishConnect(); System.out.println(“已完成与服务器的连接”); }捕获(IOE异常){ //取消频道在选择器中的注册 e、 printStackTrace(); 键。取消(); 返回; } //在这个频道上注册写作兴趣 key.interesttops(选择key.OP_WRITE); } /** *用作SHA1FromBytes方法的包装器 *它使用util.Random类生成一个字节数组,然后从这些字节生成一个消息摘要 *如果算法不存在,则返回一个空白字符串 */ 专用字节[]generateMessageDigest() { 随机=新随机(); 字节[]数据=新字节[8192]; 随机。下个字节(数据); 字符串摘要=”; 试一试{ 摘要=实用程序.SHA1FromBytes(数据); //将其添加到hashCodes链接列表 hashcode.add(摘要); System.out.println(“生成摘要:+摘要”); }捕获(无算法异常){ //TODO自动生成的捕捉块 e、 printStackTrace(); } 返回数据; } /** *从套接字的输入流中读取消息摘要 *@返回从输入流读取的消息摘要,如果读取时出现问题,则返回“” *在没有更多数据可读取之前要执行读取吗? *TODO除非读取时出现异常,否则不要关闭套接字通道 */ 私有void readData(SelectionKey)引发IOException {
//TODO: Figure out why the data is being read over and over again
    public void run()
    {

            while(true)
            {
                try{


                // Process potential change requests
                processChangeRequests();    
                //select all the things! returns the amount of channels that are ready 

                //PPP: Select is stuck after accepted socket is changed to OP_READ -- data is not read
                this.selector.select();

                //DEBUG
                System.out.println("Selector Selected Something!");

                //get the set of keys of the channels that are ready
                Iterator<SelectionKey> keyIterator = selector.selectedKeys().iterator();

                while(keyIterator.hasNext()) {

                    //get the key itself
                    SelectionKey key = keyIterator.next();
                    keyIterator.remove();

                    System.out.println("key: "+key.interestOps());

                    if(!key.isValid())
                    {
                        continue;
                    }

                    //conditions
                    if(key.isAcceptable()) {
                        // a connection was accepted by a ServerSocketChannel.
                        this.accept(key);
                    } 
                    else if (key.isReadable()) {
                        // a channel is ready for reading
                        this.readData(key);
                    } 
                    else if (key.isWritable()) {
                        // a channel is ready for writing

                        //this.fPool.submitTask(new MessageDigestProcessor(key,this.buffer.array()));
                    }


                }
                //fPool.submitTask(new MessageDigestProcessor(socket));
            }catch (Exception e) { e.printStackTrace(); }
        }
    }

    private void accept(SelectionKey key) throws IOException
    {
        System.out.println("Accepted Connection!");
        ServerSocketChannel serverSocketChannel = (ServerSocketChannel)key.channel();
        SocketChannel clientSocketChannel = serverSocketChannel.accept();
        clientSocketChannel.configureBlocking(false);
        clientSocketChannel.register(this.selector, SelectionKey.OP_READ);
    }

/**
     * Reads a message digest from the input stream from the socket
     * @return the message digest read from the input stream or "" if there was a problem reading
     * TODO read until there is no more data to be read?
     * TODO do not close the socket channels unless there is an exception from reading
     */
    private void readData(SelectionKey key) throws IOException
    {
        SocketChannel clientSocketChannel = (SocketChannel) key.channel();
        //DEBUG
        System.out.println("Message received from: "+clientSocketChannel.socket().getInetAddress());
        //clear the buffer before reading
        this.buffer.clear();
        int numRead;
        try
        {
            numRead = clientSocketChannel.read(this.buffer);    
            //DEBUG
            System.out.println("num read: "+numRead);

        } catch (IOException e)
        {
            key.cancel();
            clientSocketChannel.close();
            return;
        }

        if(numRead==-1)
        {
            key.cancel();
            key.channel().close();
            return;
        }

        //DEBUG
        try {
            System.out.println(Utility.SHA1FromBytes(this.buffer.array()));
        } catch (NoSuchAlgorithmException e) {
            // TODO Auto-generated catch block
            e.printStackTrace();
        }

        //time for writing!
        key.interestOps(SelectionKey.OP_WRITE);

    }
package cs455.scaling;

import java.security.NoSuchAlgorithmException;
import java.util.Iterator;
import java.util.LinkedList;
import java.util.List;
import java.util.Random;
import java.io.IOException;
import java.net.InetAddress;
import java.net.InetSocketAddress;
import java.net.UnknownHostException;
import java.nio.ByteBuffer;
import java.nio.channels.SelectionKey;
import java.nio.channels.Selector;
import java.nio.channels.SocketChannel;

public class Client implements Runnable {

    //stores all the hash codes for all messages that are sent to the server
    private final LinkedList<String> hashCodes = new LinkedList<String>();
    private final long messageRate;
    private final ByteBuffer buffer = ByteBuffer.allocate(8192);
    private final Selector selector;
    private final InetSocketAddress serverSocketAddress;//maintain an open connection at all times, bro. Why should I shut it?
    private final List<ChangeRequest> changeRequests = new LinkedList<ChangeRequest>();
    //private final Thread senderThread;


    public Client(String ipAddress, int port, long messageRate) throws UnknownHostException, IOException
    {
        this.serverSocketAddress = new InetSocketAddress(InetAddress.getByName(ipAddress),port);
        this.messageRate = messageRate;
        this.selector = Selector.open();
//      senderThread = new Thread(new MessageDigestSender(this));
//      senderThread.start();
    }

    public long getMessageRate()
    {
        return messageRate;
    }

    /**
     * Generates a message digest and sends it over the connected socket
     * TODO open new connection each time a send needs to occur?
     * @throws IOException
     */
    public void sendMessageDigest() throws IOException
    {
        initConnection();
        //generate the message
        byte [] data = generateMessageDigest();
        //prepare the data
        buffer.clear();
        buffer.put(data);

        this.selector.wakeup();
    }

    /**
     * Does the actual writing of the message
     * @param SelectionKey key that represents the channel that is being written to
     */
    private void write(SelectionKey key) throws IOException
    {
        SocketChannel socketChannel = (SocketChannel) key.channel();
        socketChannel.write(buffer);
        System.out.println("Wrote data to Server...");
        key.interestOps(SelectionKey.OP_READ);//not interested in writing for right now -- wait for message from the server
    }

    public void run()
    {
        while(true)
        {
            try{

                //process the socket channel op changes
                processChangeRequests();

                this.selector.select();

                //get the set of keys of the channels that are ready
                Iterator<SelectionKey> keyIterator = selector.selectedKeys().iterator();

                while(keyIterator.hasNext()) {

                    //get the key itself
                    SelectionKey key = keyIterator.next();
                    keyIterator.remove();

                    //System.out.println(key.interestOps());

                    //avoid invalid keys
                    if(!key.isValid())
                    {
                        continue;
                    }   
                    if (key.isConnectable()) {
                        this.finishConnection(key);
                    } else if (key.isReadable()) {
                        this.readData(key);
                    } else if (key.isWritable()) {
                        this.write(key);
                    }
                }
            } catch (Exception e) { e.printStackTrace(); }
        } 
    }

    /**
     * Method that queues up changes that need to be made to selection keys before they are processed
     * this is useful for when multiple threads need to make changes to selection keys
     * XXX: Used when the caller is NOT the selecting thread
     */
    private void processChangeRequests() throws IOException
    {
        synchronized(this.changeRequests)
        {
            Iterator<ChangeRequest> changes = this.changeRequests.iterator();
            while(changes.hasNext())
            {
                ChangeRequest changeRequest = changes.next();
                switch(changeRequest.type)
                {
                    case(ChangeRequest.CHANGE_OP):
                        changeRequest.channel.keyFor(this.selector).interestOps(changeRequest.ops);
                        break;
                    case ChangeRequest.REGISTER:
                        changeRequest.channel.register(this.selector, changeRequest.ops);
                        break;
                    }
            }
            this.changeRequests.clear();
        }
    }


    /**
     * Initialize the socket channel on the specified ip address and port
     * configure it for non-blocking
     * @param ipAddress
     * @param port
     * @throws IOException
     */
    private void initConnection() throws IOException
    {
        SocketChannel socketChannel = SocketChannel.open();
        socketChannel.configureBlocking(false);
        socketChannel.connect(this.serverSocketAddress);

        //a request is made because the selecting thread is not the caller of this function
        synchronized(this.changeRequests){
            this.changeRequests.add(new ChangeRequest(socketChannel, ChangeRequest.REGISTER,SelectionKey.OP_CONNECT));
        }
    }

    /**
     * Finish the connection by calling finishConnect() on the channel and then setting it to OP_WRITE
     * @param key
     */
    private void finishConnection(SelectionKey key)
    {
        // a connection was established with a remote server.
        SocketChannel socketChannel = (SocketChannel) key.channel();

        // Finish the connection. If the connection operation failed
        // this will raise an IOException.
        try {
            socketChannel.finishConnect();
            System.out.println("Finished connecting to server");
        } catch (IOException e) {
          // Cancel the channel's registration with our selector
            e.printStackTrace();
            key.cancel();
          return;
        }

        // Register an interest in writing on this channel
        key.interestOps(SelectionKey.OP_WRITE);
    }

    /**
     * Serves as a wrapper around the SHA1FromBytes method
     * It generates a byte array using the util.Random class and then generates a message digest from those bytes
     * If the algorithm doesn't exist then a blank string is returned
     */
    private byte [] generateMessageDigest()
    {
        Random random = new Random();
        byte [] data = new byte[8192];
        random.nextBytes(data);
        String digest = "";
        try {
            digest = Utility.SHA1FromBytes(data);
            //add it to the hashCodes linkedList
            hashCodes.add(digest);
            System.out.println("Generated Digest: "+digest);
        } catch (NoSuchAlgorithmException e) {
            // TODO Auto-generated catch block
            e.printStackTrace();
        }
        return data;

    }

    /**
     * Reads a message digest from the input stream from the socket
     * @return the message digest read from the input stream or "" if there was a problem reading
     * TODO read until there is no more data to be read?
     * TODO do not close the socket channels unless there is an exception from reading
     */
    private void readData(SelectionKey key) throws IOException
    {
        SocketChannel clientSocketChannel = (SocketChannel) key.channel();
        //DEBUG
        System.out.println("Message received from: "+clientSocketChannel.socket().getInetAddress());
        //clear the buffer before reading
        this.buffer.clear();
        int numRead;
        try
        {
            numRead = clientSocketChannel.read(this.buffer);    
            //DEBUG
            System.out.println("num read: "+numRead);

        } catch (IOException e)
        {
            //problem reading from a socket channel
            e.printStackTrace();
            key.cancel();
            clientSocketChannel.close();
            return;
        }

        this.buffer.flip();
        System.out.println("Received Message Digest: "+new String(this.buffer.array()));

        //done! open business later on!
        key.channel().close();
        key.channel().keyFor(this.selector).cancel();


    }


    public static void main(String [] args)
    {
        String serverHost = "";
        int serverPort = 0;
        long messageRate = 0;

        if(args.length<3)
        {
            System.err.println("Format: java cs455.scaling.Client [server-host] [server-port] [message-rate]");
            System.exit(0);
        }

        //parse the arguments out
        try{

            serverHost = args[0];
            serverPort = Integer.parseInt(args[1]);
            messageRate = Long.parseLong(args[2]);

        } catch(NumberFormatException ne) {
            ne.printStackTrace();
        } catch (ArrayIndexOutOfBoundsException ae)
        {
            ae.printStackTrace();
        }

        //start the client
        try
        {
                Client client = new Client(serverHost,serverPort,messageRate);
                Thread t = new Thread(client);
                t.start();
                client.sendMessageDigest();

        } catch(IOException i)
        {
            i.printStackTrace();
        }

    }
}